- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Receive a notification and propagate it to the local coordinator
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Pass along the found abort notification to the listener
- 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) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Abort a cache flush.
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Abort a procedure.
- abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Abort the procedure with the given name
- abortProcess() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
-
- abortServer(CoprocessorEnvironment, 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.StripeMultiFileWriter
-
- abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- AbstractHFileReader - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
readers.
- AbstractHFileReader(Path, FixedFileTrailer, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- AbstractHFileReader.BlockIndexNotLoadedException - Exception in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileReader.BlockIndexNotLoadedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.BlockIndexNotLoadedException
-
- AbstractHFileReader.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.
- AbstractHFileReader.NotSeekedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.NotSeekedException
-
- AbstractHFileReader.Scanner - Class in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileReader.Scanner(HFile.Reader, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- AbstractHFileWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
writers.
- AbstractHFileWriter(CacheConfig, FSDataOutputStream, Path, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Block has been accessed.
- AccessController - Class in org.apache.hadoop.hbase.security.access
-
Provides basic authorization checks for data access and administrative
operations.
- AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
-
- AccessControlLists - Class in org.apache.hadoop.hbase.security.access
-
Maintains lists of permission grants to users and groups to allow for
authorization checks by
AccessController
.
- AccessControlLists() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Delimiter to separate user, column family, and qualifier in
_acl_ table info: column keys
- ACL_LIST_FAMILY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Column family used to store ACL grants
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Internal storage table for access control lists
- ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
KV tag to store per cell access control lists
- acquire() - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
Acquire the lock, waiting indefinitely until the lock is released or
the thread is interrupted.
- acquire() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
-
Acquire the lock, with the configured lock timeout.
- acquire() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Acquire the lock, waiting indefinitely until the lock is released or
the thread is interrupted.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Flush the online regions on this rs for the target table.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should gather and hold required resources (locks, disk
space, etc) to satisfy the Procedures barrier condition.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquireDelegationToken(FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Acquire the delegation token for the specified filesytem.
- acquiredLock - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- acquireRegionLock(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
To avoid racing with AM, external entities may need to lock a region,
for example, when SSH checks what regions to skip re-assigning.
- ActiveMasterManager - Class in org.apache.hadoop.hbase.master
-
Handles everything on master-side related to master election.
- actualErrorRate() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
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.ByteBloomFilter
-
Computes the actual error rate for the given number of elements, number
of bits, and number of hash functions.
- add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add configuration-less constraints to the table.
- add(HTableDescriptor, Pair<Class<? extends Constraint>, Configuration>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add constraints and their associated configurations to the table.
- add(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add a
Constraint
to the table with the given configuration
- add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
This will add the distribution from input to this object
- add(Map.Entry<BlockCacheKey, BucketCache.BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Attempt to add the specified entry to this queue.
- add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Attempt to add the specified cached block to this queue.
- add(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Adds the server to the dead server list if it's not there already.
- add(String) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Append the given message to this buffer, automatically evicting
older messages until the desired memory limit is achieved.
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Write an update
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Add the specified cell to the list of deletes to check against for
this row operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write an update
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Add the specified KeyValue to the list of deletes to check against for
this row operation.
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Adds a value to the memstore
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- add(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Add or update descriptor
- add(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Add the specified binary to the bloom filter.
- add(byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
Adds a Bloom filter key.
- add(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Adds (or updates) the table descriptor to the FileSystem
and updates the local cache with it.
- add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Adds an edge to the split calculator
- add(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- addAll(Collection<? extends T>) - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- addAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Increase the size of mem store in this region and the size of global mem
store
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- addAndGetRegionReplayEditsSize(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Add memStoreSize to replayEditsPerRegion.
- addBack(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- 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.
- addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- addChangedReaderObserver(ChangedReadersObserver) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- addChildExp(ExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- addChildExps(List<ExpressionNode>) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- 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.WALKey
-
Marks that the cluster with the given clusterId has consumed the change
- addColumn(TableName, HColumnDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Add column to a table
- addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- addColumn(TableName, HColumnDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Add a new column to an existing table
- AddColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to add a column family to an existing table.
- AddColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- AddColumnFamilyProcedure(MasterProcedureEnv, TableName, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Adds an array of columns specified using old format, family:qualifier.
- addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds compaction results into the structure.
- addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- addContext(Context, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addContext(String, String, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a context
- addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add default apps.
- addDefaultServlets() - 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.HFileWriterV2
-
- 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.
- addDependencyJars(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.
- addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Add an endpoint that the HTTP server should listen to.
- 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.
- addFileInfoToException(IOException) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- 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
-
- 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
- addFilterPathMapping(String, Context) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add the path spec to the filter path mapping.
- addFront(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- 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.HFileWriterV2
-
- 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.
- addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- 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.
- 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
- 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.HFileWriterV2
-
- addInternalServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server.
- addInternalServlet(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server, specifying whether or not to
protect with Kerberos authentication.
- addJerseyResourcePackage(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a Jersey resource package.
- addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addLabels(RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
VisibilityEndpoint service related methods
- addLabels(List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Adds the set of labels into the system.
- addLease(Leases.Lease) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Inserts lease.
- addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
Listen for failures to a given process.
- addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
- 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
-
- addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- 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.
- addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- 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
-
- addOperationSize(OperationQuota.OperationType, long) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addOperationSize(OperationQuota.OperationType, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Add the average size of the specified operation type.
- addOperationSize(OperationQuota.OperationType, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- addPlan(String, RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a regionPlan for the specified region.
- addPlans(Map<String, RegionPlan>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a map of region plans.
- addPushSize(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Add current size to the current cycle's total push size
- addPutToKv(Put, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- 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(Path, HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Creates a 'manifest' for the specified region, by reading directly from the disk.
- addRegionInfo(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- 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
-
- addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Add the specified set of regions to the hbase:meta table.
- addRegionsToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
Add the specified set of regions to the hbase:meta table.
- addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- addRegionToMETA(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Inserts a new region's meta information into the passed
meta
region.
- addRegionToSnapshot(HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Complete taking the snapshot on the region.
- addReplicas(HTableDescriptor, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
- 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.
- addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addServer(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a servlet in the server.
- addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- 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
- addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Add a new normal source to this region server
- addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- addSystemLabel(Region, Map<String, Integer>, Map<String, List<Integer>>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Add the named table to be those being archived.
- addTableDescriptor(HTableDescriptor) - 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
-
- addTableToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- addToMovedRegions(String, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToOnlineRegions(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToOnlineRegions(Region) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Add to online regions.
- 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
-
- addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addWAL(WAL) - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- addWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
add weight
- admin - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- 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
-
- affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Used to manufacture race condition reliably.
- afterExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Called after compaction is executed by CompactSplitThread; for use by coproc subclasses.
- afterProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
-
Called after any event is processed
- AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
-
Snapshot of block cache age in cache.
- AggregateImplementation<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
-
A concrete AggregateProtocol implementation.
- AggregateImplementation() - Constructor for class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- allocate() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
Allocate a block in this bucket, return the offset representing the
position in physical space
- allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Allocate a block with specified size.
- allocateBytes(int) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Allocate a slice of the given length.
- allocateBytes(int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocate a slice of the given length.
- allocBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Allocate memory for the bloom filter data.
- allocBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- allocBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- allow(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- append(LoggingEvent) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
Append the given key/value pair to the file info, optionally checking the
key prefix.
- append(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add key/value to file.
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
Add key/value to file.
- append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSink
-
- append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more append operations on a row.
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, AtomicLong, boolean, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, AtomicLong, boolean, List<Cell>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Append a set of edits to the WAL.
- append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- append(WALSplitter.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
-
Append a log entry into the corresponding region buffer.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Add to the file info.
- 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.regionserver.StoreFile.Writer
-
- 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.HFileWriterV2
-
Add a meta block to the end of the file.
- appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Writes meta data.
- appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
Print all of the thread's information and stack traces.
- appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Add TimestampRange and earliest put timestamp to Metadata
- applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Convience method to change metrics when a batch of operations are applied.
- applyCompactionPolicy(List<StoreFile>, boolean, boolean, int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
- archiveFamily(FileSystem, Configuration, HRegionInfo, 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
- archiveRegion(Configuration, FileSystem, HRegionInfo) - 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.
- archiveStoreFile(Configuration, FileSystem, HRegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive the store file
- archiveStoreFiles(Configuration, FileSystem, HRegionInfo, Path, byte[], Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove the store files, either by archiving them or outright deletion
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Checks if there are currently any dead servers being processed by the
master.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Checks if any dead servers are currently in progress.
- areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Subclasses should implement this to return true if the cluster has nodes that hosts
multiple replicas for the same region, or, if there are multiple racks and the same
rack hosts replicas of the same region
- areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- 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
-
- assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- assertBulkLoadHFileOk(Path) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
This throws a WrongRegionException if the HFile does not fit in this region, or an
InvalidHFileException if the HFile is not valid.
- assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- assign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the specified region.
- assign(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Use care with forceNewPlan.
- assign(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns specified regions retaining assignments, if any.
- assign(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns specified regions round robin, if any.
- AssignCallable - Class in org.apache.hadoop.hbase.master
-
A callable object that invokes the corresponding action that needs to be
taken for assignment of a region in transition.
- AssignCallable(AssignmentManager, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.master.AssignCallable
-
- assignMasterRegions(Collection<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Assign the regions that should be on master regionserver.
- AssignmentListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of assignment events.
- AssignmentManager - Class in org.apache.hadoop.hbase.master
-
Manages and performs region assignment.
- AssignmentManager(Server, ServerManager, LoadBalancer, ExecutorService, MetricsMaster, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager
-
Constructs a new assignment manager.
- assignmentManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- AssignmentManager.ServerHostRegion - Enum in org.apache.hadoop.hbase.master
-
- AssignmentManagerStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- AssignmentManagerStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- AssignmentManagerStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- AssignmentManagerStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmplImpl(TemplateManager, AssignmentManagerStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
-
- AssignmentVerificationReport - Class in org.apache.hadoop.hbase.master
-
- AssignmentVerificationReport() - Constructor for class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- assignMeta(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the hbase:meta region or a replica.
- assignRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- assignRegions(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- assignRegions(AssignmentManager, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Triggers a bulk assignment of the specified regions
- atLeast(WALKey.Version) - Method in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- attemptToOwnTask(boolean, ZooKeeperWatcher, ServerName, String, ZooKeeperProtos.SplitLogTask.RecoveryMode, 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
-
- ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationKey() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- AuthenticationKey(int, long, SecretKey) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- AuthenticationTokenSecretManager - Class in org.apache.hadoop.hbase.security.token
-
Manages an internal list of secret keys used to sign new authentication
tokens as they are generated, and to valid existing tokens used for
authentication.
- AuthenticationTokenSecretManager(Configuration, ZooKeeperWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
Create a new secret manager instance for generating keys.
- authManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Authorize the incoming client connection.
- authorize(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Authorize a global permission based on ACLs for the given user and the
user's groups.
- authorize(User, TableName, Cell, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Authorize a user for a given KV.
- authorize(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorizeGroup(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks global authorization for a given action for a group, based on the stored
permissions.
- authorizeGroup(String, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table, column family and column for a group, based
on the stored permissions.
- authorizeUser(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
- authorizeUser(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- AuthResult - Class in org.apache.hadoop.hbase.security.access
-
Represents the result of an authorization check for logging and error
reporting.
- AuthResult(boolean, String, String, User, Permission.Action, TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, String) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult.Params - Class in org.apache.hadoop.hbase.security.access
-
- AuthResult.Params() - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- authTokenSecretMgr - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- 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
-
- avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average key length read from file info
- avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average value length read from file info
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- 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_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_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.
- Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
-
Cacheable is an interface that allows for an object to be cached.
- CacheableDeserializer<T extends Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
-
Interface for a deserializer.
- CacheableDeserializerIdManager - Class in org.apache.hadoop.hbase.io.hfile
-
- CacheableDeserializerIdManager() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache.
- 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.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - 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.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- cacheBlockWithWait(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block to ramCache
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Block cache configuration.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Cache configuration for caching data on write.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
-
Stores all of the cache objects and configuration for a single HFile.
- CacheConfig(Configuration, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and
family descriptor.
- 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(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Constructs a cache configuration copied from the specified configuration.
- cacheConfig - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CachedBlock - Interface in org.apache.hadoop.hbase.io.hfile
-
- CachedEntryQueue - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
A memory-bound queue that will grow until an element brings total size larger
than maxSize.
- CachedEntryQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- cacheFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CacheFullException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
-
- cacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Total size of all elements in this queue.
- 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
-
- 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.
- calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- calculateRebalancedSplits(List<InputSplit>, JobContext, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the number of MapReduce input splits for the map tasks.
- calculateResultSize(Result) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateResultSize(List<Result>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a server side method, which is invoked over RPC.
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- call() - Method in class org.apache.hadoop.hbase.master.AssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.master.UnAssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
This call is the main execution thread of the barriered procedure.
- call() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- CALL_QUEUE_HANDLER_FACTOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
If set to 'deadline', uses a priority queue and deprioritize long-running scans
- CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_TYPE_FIFO_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- callQueueSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a running count of the size of all outstanding calls by size.
- CallRunner - Class in org.apache.hadoop.hbase.ipc
-
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler
.
- Canary - Class in org.apache.hadoop.hbase.tool
-
HBase Canary Tool, that that can be used to do
"canary monitoring" of a running HBase cluster.
- Canary() - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary(Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary.ExtendedSink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.Monitor - Class in org.apache.hadoop.hbase.tool
-
- Canary.Monitor(Connection, String[], boolean, Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- Canary.RegionServerStdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.RegionServerStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.RegionServerStdOutSink
-
- Canary.Sink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- cancel(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Actively cancel a running snapshot.
- cancel(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Method to cancel the Subprocedure by injecting an exception from and external source.
- cancel() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Cancels the compaction progress, setting things to 0.
- CancelableProgressable - Interface in org.apache.hadoop.hbase.util
-
Similar interface as Progressable
but returns
a boolean to support canceling the operation.
- cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Client explicitly cancels a lease.
- cancelMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Cancel a write insert that failed.
- cancelRequestedCompaction(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- cancelRequestedCompaction(CompactionContext) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- canExecute() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Is there at least one resource available to allow execution?
- canExecute(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Are there enough available resources to allow execution?
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- 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.security.visibility.VisibilityReplicationEndpoint
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CatalogJanitor - Class in org.apache.hadoop.hbase.master
-
A janitor for the catalog tables.
- catalogJanitorEnabled - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- ceiling(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- CELL_TTL_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CELL_VISIBILITY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- 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
-
- 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.ProtobufLogReader
-
- cellEncoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- cellScanner - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- CellSkipListSet - Class in org.apache.hadoop.hbase.regionserver
-
- cellsPerHeartbeatCheck - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- ChainWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
A
WALEntryFilter
which contains multiple filters and applies them
in chain order
- ChainWALEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- ChainWALEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
-
If set of MapFile.Readers in Store change, implementors are notified.
- channel - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- channelWrite(GatheringByteChannel, BufferChain) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
-
Check a
Put
to ensure it is valid for the table.
- checkAccess(UserGroupInformation, FileStatus, FsAction) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Throw an exception if an action is not permitted by a user on a file.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
If the table is found in the given state the in-memory state is removed.
- checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
If the table is found in the given state the in-memory state is removed.
- checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndUpdateNamespaceRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkBlockBoundary() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
At a block boundary, write all the inline blocks and opens new block.
- checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Called before actual region closing to check that we can do close operation
on this region.
- checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
In ZK-based version we're checking for bad znode state, e.g.
- checkClusterIdExists(FileSystem, Path, int) - 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(byte[], int, int, byte) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- 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
- checkFamilies(Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkFamilies(Collection<byte[]>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the collection of families for validity.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Checks to see if the file system is still accessible.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Checks to see if the file system is still accessible.
- checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks to see if the specified file system is available
- 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.
- checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks a path to see if it is a valid hfile.
- checkKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Checks that the given Cell's key does not violate the key order.
- checkKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Check key and value lengths are wholesome.
- checkLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
StoreFiles will not be scanned.
- checkOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
MemStore will not be scanned.
- checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
-
Take actions on the event of an OutOfMemoryError.
- checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Called to verify that this server is up and running.
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Checks if the output target exists.
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- checkQuota(int, int, int) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Checks if it is possible to execute the specified operation.
- checkQuota(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Checks if it is possible to execute the specified operation.
- checkQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(Region, List<ClientProtos.Action>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(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(HRegionInfo) - 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.
- checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkReadsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
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.
- checkReseek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- checkScanOrder(Cell, Cell, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Check whether scan as expected order
- 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.
- checkSnapshotSupport() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Throws an exception if snapshot operations (take a snapshot, restore, clone) are not supported.
- checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return the splitpoint.
- checksumOk() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Report that checksum was ok, so we may ponder going back to HBase checksum.
- 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
-
- checkTableLocks() - Method in class org.apache.hadoop.hbase.util.hbck.TableLockChecker
-
- 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.
- checkTableModifiable(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Check whether a table is modifiable - exists and either offline or online with config set
- 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
-
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
-
Check that the task is still there
- checkTaskStillAvailable(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- checkTimestamps(Map<byte[], List<Cell>>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkTimestamps(Map<byte[], List<Cell>>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the collection of families for valid timestamps
- checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
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(byte[], int, int, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- childZNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
This method is used during rollback
- clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
clean the split transaction
- clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
- cleanAllPreviousInstances(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- CleanerChore<T extends FileCleanerDelegate> - Class in org.apache.hadoop.hbase.master.cleaner
-
Abstract Cleaner that uses a chain of delegates to clean a directory of files
- CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanersChain - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanMergeQualifier(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
Checks if the specified region has merge qualifiers, if so, try to clean
them
- cleanMovedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Remove the expired entries from the moved regions list.
- cleanOldLogs(String, String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Cleans a log file and all older files from ZK.
- cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
A dead server that comes back alive has a different start code.
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- cleanup() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Explicitly mark this status as able to be cleaned up,
even though it might not be complete.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Cancel threads if they haven't finished.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Users should override this method.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Cancel threads if they haven't finished.
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- clear() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Clears all entries from the map.
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Removes all metrics about this Source.
- clear() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- clear() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- clear() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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.
- clearArchive() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- clearAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- clearAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Removes given labels from user's globally authorized list of labels.
- clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Clears the cache.
- clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- 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
-
- clearLastAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- clearRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Clear a region from replayEditsPerRegion.
- clearSnapshot(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
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.
- clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- 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, HTableDescriptor, HRegionInfo, Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- clone() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Public exposure of Object.clone() in order to allow clients to easily
capture current state.
- cloneRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
HRegionInfo
from the snapshot region info.
- CloneSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Handler to Clone a snapshot.
- CloneSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cloneTableSchema(HTableDescriptor, TableName) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new table descriptor cloning the snapshot table schema.
- close() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Close this filesystem object
- close() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- close() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Close stream(s) if necessary.
- close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Close method with optional evictOnClose
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- close() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- 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.KeyValueSerialization.KeyValueDeserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
- 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() - 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.procedure.ProcedureCoordinator
-
Shutdown the thread pools and release rpc resources
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Best effort attempt to close the threadpool via Thread.interrupt.
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- close() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- close() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Cleanup method on operation completion
- close() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
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.HRegion
-
Close down this HRegion.
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- CLOSE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- 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.Leases
-
Shut down this Leases instance.
- 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.MetricsRegion
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
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(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- close() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- close() - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
Close the open connections and shutdown the batchpool
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- 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_PARAN_NODE - Static variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Shuts down this lease instance when all outstanding leases expire.
- closeAllRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Closes all regions.
- closeAndCleanCompleted - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- closeConnection(RpcServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- ClosedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles CLOSED region event on Master.
- ClosedRegionHandler(Server, AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- closeHRegion(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of the root region on a region server.
- CloseMetaHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
-
- closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
True if we opened the outputStream
(and so will close it).
- closeReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- closeReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Close the current reader
- closeRecoveredQueue(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Clear the references to the specified old source
- closeRegion(String, boolean, CloseRegionCoordination.CloseRegionDetails, 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(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Close a region on the region server.
- CloseRegionCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordinated operations for close region handlers.
- closeRegionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- CloseRegionCoordination.CloseRegionDetails - Interface in org.apache.hadoop.hbase.coordination
-
Marker interface for region closing tasks.
- CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of a region on a region server.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
This method used internally by the RegionServer to close out regions.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Closes the lock.
- closeRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Closes the region operation lock.
- closeRegionSilentlyAndWait(ClusterConnection, ServerName, HRegionInfo, 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(HConnection, ServerName, HRegionInfo) - 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.
- closeStreams() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Closes the backing streams
- closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- closing - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- clusterConnection - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cluster connection to be shared by services.
- clusterIds - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- ClusterLoadState - Class in org.apache.hadoop.hbase.master.balancer
-
Class used to hold the current state of the cluster and how balanced it is.
- ClusterLoadState(Map<ServerName, List<HRegionInfo>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- clusterStatus - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- ClusterStatusChore - Class in org.apache.hadoop.hbase.master.balancer
-
Chore that will feed the balancer the cluster status.
- ClusterStatusChore(HMaster, LoadBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- ClusterStatusPublisher - Class in org.apache.hadoop.hbase.master
-
Class to publish the cluster status to the client.
- ClusterStatusPublisher(HMaster, Configuration, Class<? extends ClusterStatusPublisher.Publisher>) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher.MulticastPublisher - Class in org.apache.hadoop.hbase.master
-
- ClusterStatusPublisher.MulticastPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- ClusterStatusPublisher.Publisher - Interface in org.apache.hadoop.hbase.master
-
- clusterStatusTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracker on cluster settings up in zookeeper.
- ClusterStatusTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Creates a cluster status tracker.
- code - Variable in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
- CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
-
Utility scanner that wraps a sortable collection and serves
as a KeyValueScanner.
- CollectionBackedScanner(SortedSet<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(SortedSet<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(KeyValue.KVComparator, Cell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
space delimited list of columns
- ColumnCount - Class in org.apache.hadoop.hbase.regionserver
-
Simple wrapper for a byte buffer and a counter.
- ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constuctor
- 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.StoreScanner
-
- COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver
-
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.
- CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- CombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- CombinedBlockCache.CombinedCacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
- combinedCacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- combineWith(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Combines the request with other request.
- comConf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Commits opening operation on HM side (steps required for "commit"
are determined by coordination implementation).
- commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
- 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.
- commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- commitWriters(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
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.
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- compact(CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Runs the compaction based on current selection.
- compact(CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- compact(CompactionRequest, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
Do a minor/major compaction on an explicit set of storefiles from a Store.
- compact(CompactionRequest, List<byte[]>, byte[], byte[], CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, List<byte[]>, byte[], byte[], CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, int, long, byte[], byte[], byte[], byte[], CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, int, long, byte[], byte[], byte[], byte[], CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, Store, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, Store, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Compact the StoreFiles.
- compact(CompactionContext, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- compact(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Synchronously compact all stores in the region.
- compact(CompactionContext, CompactionThroughputController) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Deprecated.
see compact(CompactionContext, CompactionThroughputController, User)
- compact(CompactionContext, CompactionThroughputController, User) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Compact the Bloom filter before writing metadata & data to disk.
- compactBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- compactBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- compactForTesting(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
Compact a list of files for testing.
- compactionCompression - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- CompactionConfiguration - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Compaction configuration for a particular instance of HStore.
- CompactionContext - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all "physical" details necessary to run a compaction,
and abstracts away the details specific to a particular compaction.
- CompactionContext() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- CompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compaction policy determines how to select files for compaction,
how to compact them, and how to generate the compacted files.
- CompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- compactionPolicy - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- CompactionProgress - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds information relevant for tracking the progress of a
compaction.
- CompactionProgress(long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Constructor
- CompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all logical details necessary to run a compaction.
- CompactionRequest() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
This ctor should be used by coprocessors that want to subclass CompactionRequest.
- CompactionRequest(Collection<StoreFile>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- CompactionRequestor - Interface in org.apache.hadoop.hbase.regionserver
-
- CompactionThroughputController - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
A utility that constrains the total throughput of one or more simultaneous flows (compactions) by
sleeping when necessary.
- CompactionThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- CompactionThroughputControllerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- CompactionTool - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- Compactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compactor is a compaction algorithm associated a given policy.
- compactor - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- Compactor.CellSink - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
- Compactor.FileDetails - Class in org.apache.hadoop.hbase.regionserver.compactions
-
The sole reason this class exists is that java has no ref/out/pointer parameters.
- Compactor.FileDetails() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
- compactRecentForTestingAssumingDefaultPolicy(int) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This method tries to compact N recent files for testing.
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Compact a region on the region server.
- CompactSplitThread - Class in org.apache.hadoop.hbase.regionserver
-
Compact region on request and then run split if appropriate
- compactSplitThread - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact all the stores synchronously
It is used by utilities and testing
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Key comparator
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Key comparator.
- comparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- comparator - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Comparator used to compare Bloom filter keys
- comparator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
- 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(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
Compares two KeyValue
- compare(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
-
- compare(String, String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
Compare the given key against the current key
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- compareKeyForNextColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- compareKeyForNextRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- compareTo(Runnable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Default prioritized runnable comparator which implements a FIFO ordering.
- compareTo(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- 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(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
This function will define where in the priority queue the request will
end up.
- compareTo(WALKey) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- complete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Call to indicate that additional coprocessors further down the execution
chain do not need to be invoked.
- 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() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Marks the compaction as complete by setting total to current KV count;
Total KV count is an estimate, so there might be a discrepancy otherwise.
- completeCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- completeCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Complete the cache flush.
- completeCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
It works by processing a compaction that's been written to disk.
- completeCompaction(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
It works by processing a compaction that's been written to disk.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- completeMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- completeMemstoreInsertWithSeqNum(MultiVersionConsistencyControl.WriteEntry, SequenceId) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Finish off merge transaction
- completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- completeSnapshot(Path, Path, FileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Reset the manager to allow another snapshot to proceed
- completeSnapshot(HBaseProtos.SnapshotDescription, Path, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Move the finished snapshot to its final, publicly visible directory - this marks the snapshot
as 'complete'.
- completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
Finish off split transaction
- completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Finish off split transaction, transition the zknode
- completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- CompoundBloomFilter - Class in org.apache.hadoop.hbase.util
-
A Bloom filter implementation built on top of
ByteBloomFilter
,
encapsulating a set of fixed-size Bloom filters written out at the time of
HFile
generation into the data
block stream, and loaded on demand at query time.
- CompoundBloomFilter(DataInput, HFile.Reader) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
De-serialization for compound Bloom filter metadata.
- CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.util
-
- CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.util
-
Adds methods required for writing a compound Bloom filter to the data
section of an
HFile
to the
CompoundBloomFilter
class.
- CompoundBloomFilterWriter(int, float, int, int, boolean, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- compress(byte[], Dictionary) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
-
- compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Filled when we read in the trailer.
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- 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 - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Compression context to use reading.
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- compressionContext - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- CompressionTest - Class in org.apache.hadoop.hbase.util
-
Compression validation test.
- CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
-
- 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
-
- compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- computeCost(BaseLoadBalancer.Cluster, double) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
This is the main cost function.
- computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
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.ByteBloomFilter
-
Increases the given byte size of a Bloom filter until it can be folded by
the given factor.
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo, 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
- computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
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.
- concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, 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.io.hfile.AbstractHFileReader
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- 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.master.handler.CreateTableHandler
-
- conf - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
conf object
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- CONF_CONTEXT_ATTRIBUTE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- config - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- 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
-
- configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Configuration manager is used to register/deregister and notify the configuration observers
when the regionserver is notified that there was a change in the on disk configs.
- 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
object.
- 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.ConstantSizeRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- 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
-
- 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, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- 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.
- configureIncrementalLoad(Job, HTableDescriptor, 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, Table) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets split table in map-reduce job.
- ConfigUtil - Class in org.apache.hadoop.hbase.util
-
Some configuration related utilities
- ConfigUtil() - Constructor for class org.apache.hadoop.hbase.util.ConfigUtil
-
- confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Confirm that the region merge can be performed
- confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- 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
-
- ConfServlet.BadFormatException - Exception in org.apache.hadoop.hbase.http.conf
-
- ConfServlet.BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
-
- 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() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
To repair region consistency, one must call connect() in order to repair
online state.
- connection - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- connection - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- 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
-
- connectionList - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- consolidate() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- 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(Context) - Static method in class org.apache.hadoop.hbase.util.HttpServerUtil
-
Add constraints to a Jetty Context to disallow undesirable Http methods.
- Constraint - Interface in org.apache.hadoop.hbase.constraint
-
Apply a
Constraint
(in traditional database terminology) to a HTable.
- ConstraintException - Exception in org.apache.hadoop.hbase.constraint
-
Exception that a user defined constraint throws on failure of a
Put
.
- ConstraintException() - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintProcessor - Class in org.apache.hadoop.hbase.constraint
-
- ConstraintProcessor() - Constructor for class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
Create the constraint processor.
- Constraints - Class in org.apache.hadoop.hbase.constraint
-
Utilities for adding/removing constraints from a table.
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- constructMaster(Class<? extends HMaster>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
Utility for constructing an instance of the passed HMaster class.
- constructOutputStream(DataOutput) - Static method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
Construct an OutputStream from the given DataOutput.
- constructRegionServer(Class<? extends HRegionServer>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Utility for constructing an instance of the passed HRegionServer 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.
- consumeRead(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some read amount to the quota.
- consumeRead(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- consumerLoop(BlockingQueue<CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- consumeWrite(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some write amount to the quota.
- consumeWrite(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- contains(byte[], int, int, ByteBuffer) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
Check if the specified key is contained in the bloom filter.
- contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], int, int, ByteBuffer, int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Whether the cache contains block with specified cacheKey
- containsKey(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether there is a value in the map for the specified key.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether this is a mapping which contains the specified value.
- control(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Control the compaction throughput.
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- controller - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- controllerConnectionFailure(String, Throwable, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
The connection to the rest of the procedure group (member and coordinator) has been
broken/lost/failed.
- convert() - Method in class org.apache.hadoop.hbase.io.Reference
-
- convert(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- convertThrowableToIOE(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the BigInteger represented by the byte array
- convertToByte(BigInteger, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns an array of bytes corresponding to an array of BigIntegers
- 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.
- CoordinatedStateManagerFactory - Class in org.apache.hadoop.hbase
-
- CoordinatedStateManagerFactory() - Constructor for class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
-
- coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- CoprocessorHConnection - Class in org.apache.hadoop.hbase.client
-
Connection to an HTable from within a Coprocessor.
- CoprocessorHConnection(ClusterConnection, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Deprecated.
delegate is not used
- CoprocessorHConnection(HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Constructor that uses server configuration
- CoprocessorHConnection(Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Constructor that accepts custom configuration
- CoprocessorHost<E extends CoprocessorEnvironment> - 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
-
- CoprocessorHost.Environment - Class in org.apache.hadoop.hbase.coprocessor
-
Encapsulation of the environment of each coprocessor
- CoprocessorHost.Environment(Coprocessor, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Constructor
- coprocessors - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Ordered set of loaded coprocessors with lock
- COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- copyDeadServersSince(long) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Extract all the servers dead since a given time, and sort them.
- 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.
- 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(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- 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, Throwable) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- countPerRow - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- create(Configuration) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Create an archive tracker for the passed in server
- create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- create(Configuration, FileSystem, Path, HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, HRegionInfo, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- 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(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.
- 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(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Create the FlushPolicy configured for the given table.
- create(Configuration, FlushRequester, Server) - Static method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- create(Region, Region, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
Create a merge transaction
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Create the RegionSplitPolicy configured for the given table.
- create(Configuration, PriorityFunction, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
Deprecated.
- create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
Deprecated.
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- create(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
Create a split transaction
- create(Store, Configuration, KeyValue.KVComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine configured for the given Store.
- create(Configuration, String, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the
cellCodecClsName
and
CompressionContext, if
cellCodecClsName
is specified.
- create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the
CompressionContext.
- create(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Return a SnapshotManifest instance, used for writing a snapshot.
- create(FileSystem, Path, FsPermission, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- createAndGet(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Creates the singleton instance, if not yet present, and returns the same.
- createAndPrepare(T, ObserverContext<T>) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Instantiates a new ObserverContext instance if the passed reference is
null
and sets the environment in the new or existing instance.
- createAnother() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates another similar Bloom filter.
- createBaseListener(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Create a required listener for the Jetty instance listening on the port
provided.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Prepare an ordered pair of row and qualifier to be compared using
KeyValue.KeyComparator.
- createBottomReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- createBulkLoadEvent(HRegionInfo, WALProtos.BulkLoadDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Create a bulk loader WALEdit
- createBySize(int, double, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates a Bloom filter of the given size.
- createCleanupScheduledChore(Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Creates a scheduled chore that is used to clean up old nonces.
- createCluster(List<ServerName>, Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- createClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Create a 'smarter' HConnection, one that is capable of by-passing RPC if the request is to
the local server.
- 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(HRegionInfo, WALProtos.CompactionDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Create a compaction WALEdit
- createComparator(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine's components.
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- createDefaultChannelConnector() - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
- 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
StoreFile
writing.
- createDestinationServersList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Creates a list of possible destinations for a region.
- createDestinationServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- createEmptyRequest(StripeCompactionPolicy.StripeInformationProvider, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Called when a new Coprocessor class is loaded
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- createExecutor(Configuration, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- createFileScanners(Collection<StoreFile>, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Creates file scanners for compaction.
- createFlushContext(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createFlushContext(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- createFlushWALEdit(HRegionInfo, WALProtos.FlushDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- createFromFileInfo(HFile.FileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- createFromHFileLink(Configuration, FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink starting from a hfileLink name
- 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.
- createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>, CreateTableProcedure.CreateHdfsRegions) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- 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
StoreFile
writing.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Create a key by concatenating multiple column values.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Create a key by concatenating multiple column values.
- createHDFSRegionDir(Configuration, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Creates, flushes, and closes a new region.
- createHdfsRegions(MasterProcedureEnv, Path, TableName, List<HRegionInfo>) - Method in interface org.apache.hadoop.hbase.master.procedure.CreateTableProcedure.CreateHdfsRegions
-
- createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
- createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- createHFileLinkName(HRegionInfo, 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
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- createHRegionInfos(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
- createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createInProgressTag(Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Create in-progress tag under .tmp of in-progress snapshot
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Create a lease and insert it to the map of leases.
- createMasterThread(Configuration, CoordinatedStateManager, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a new namespace
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
The org.apache.hadoop.fs.FilterFileSystem does not yet support
createNonRecursive.
- createOutputStream(Configuration, FileSystem, Path, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
A helper method to create HFile output streams in constructors
- createPassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- 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
- createReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader(FileSystem, Path, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- createReader(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the WAL.
- createReader(FileSystem, Path, CancelableProgressable, boolean) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, accept custom reader classes from conf.
- createReaderIgnoreCustomClass(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, ignore custom reader classes from conf.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- 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
-
- 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.
- createRegion(Configuration, Path, Path, HTableDescriptor, HRegionInfo, ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionEventWALEdit(HRegionInfo, WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRegionOnFileSystem(Configuration, FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Create a new Region on file-system.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[], 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, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(ThreadPoolExecutor, Configuration, Path, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionServerStatusStub() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the current master from ZooKeeper and open the RPC connection to it.
- createRegionServerThread(Configuration, CoordinatedStateManager, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a region to RegionStates.
- createRegionState(HRegionInfo, RegionState.State, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a region to RegionStates with the specified state.
- createRegionStates(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a list of regions to RegionStates.
- createRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createScanner(Store, List<StoreFileScanner>, ScanType, long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createScanner(Store, List<StoreFileScanner>, long, long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createServerSocket(int) - Method in class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
-
- 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
-
- createSocket(String, int) - Method in class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
-
- createSSLEngine() - Method in class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
-
- createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
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.replication.VerifyReplication
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
This is separated from execution so that we can detect and handle the case where the
subprocedure is invalid and inactionable due to bad info (like DISABLED snapshot type being
sent here)
- createTable(HTableDescriptor, byte[][], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createTable(HTableDescriptor, byte[][], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a table using the given table definition.
- createTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptor(HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptorForTableDirectory(Path, HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create a new HTableDescriptor in HDFS in the specified table directory.
- CreateTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handler to create a table.
- CreateTableHandler(Server, MasterFileSystem, HTableDescriptor, Configuration, HRegionInfo[], MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- createTableLockManager(Configuration, ZooKeeperWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.master.TableLockManager
-
Creates and returns a TableLockManager according to the configuration
- CreateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- CreateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[], ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure.CreateHdfsRegions - Interface in org.apache.hadoop.hbase.master.procedure
-
- 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.
- createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- 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.
- createVisibilityExpTags(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- createVisibilityExpTags(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates tags corresponding to given visibility expression.
- createVisibilityExpTags(String, boolean, boolean, Set<Integer>, VisibilityLabelOrdinalProvider) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- createVisibilityLabelFilter(Region, Authorizations) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- 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.
- createWrapper(List<HTableInterface>, TableName, CoprocessorHost.Environment, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- createWriter(FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- createWriter() - Method in interface org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.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(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
public because of FSHLog.
- createWriter(Path) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This method allows subclasses to inject different writers without having to
extend other methods like rollWriter().
- createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- csm - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ctx - Variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- cur_worker_name - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- 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.regionserver.KeyValueHeap
-
The current sub-scanner, i.e.
- 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
-
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the completed count of key values in currently running compaction
- CurrentHourProvider - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- currentTrailerSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
- currKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTSLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- GeneralBulkAssigner - Class in org.apache.hadoop.hbase.master
-
Run bulk assign.
- GeneralBulkAssigner(Server, Map<ServerName, List<HRegionInfo>>, AssignmentManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- 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.
- generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- get(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a new HFileSystem object, similar to FileSystem.get().
- get(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- get(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Get singleton instance.
- get(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Retrieves the value associated with the specified key.
- get(Get) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(Get, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get data from a table.
- get(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- get() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- get(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- 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(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- get75thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get95thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get98thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get999thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get99thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getAbortNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator or member to trigger an abort
of the global barrier acquisition or execution in subprocedures.
- getAbortZNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbortZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquireBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
acquire on each subprocedure.
- getAcquiredBarrier() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquiredBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAction() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active handler.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getActiveUser() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
.
- getAdmin() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller doesn't close the admin afterwards.
- 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.regionserver.MetricsSink
-
Get the Age of Last Applied Op
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get AgeOfLastShippedOp
- getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all HTableDescriptors.
- getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns a map from table name to table descriptor for all tables.
- getAllExecutorStatuses() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getAndRemoveScopes() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getArchiveZNode(Configuration, ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
- getArchivingEnabled(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getArchivingEnabled(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAssignmentManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAssignmentMap() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
- getAssignmentsByTable() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
This is an EXPENSIVE clone.
- getAttribute(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the value in the webapp context.
- getAttributesKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
Deprecated.
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
- getAvailable() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Compute the average load across all region servers.
- getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a Pair with first object as Sum and second object as row count,
computed for a given combination of column qualifier and column family in
the given row range as defined in the Scan object.
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the underlying filesystem
- 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
- 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(int) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getBalancer() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getBaseOffset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getBatch() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcn__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcv__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBestLocations(Configuration, HDFSBlocksDistribution) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
This computes the locations to be passed from the InputSplit.
- 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.bucket.BucketCache
-
Get the buffer of the block with the specified key.
- 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.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
-
- getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache.
- getBlockCaches() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- 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.bucket.BucketCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
- 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.Region
-
- getBlockForCaching(CacheConfig) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Creates a new HFileBlock.
- 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
-
- getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the locality index of a given host
- getBlockPriority() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
The type of block this data should use.
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getBuckets() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the buffer this block stores internally.
- getBufferReadOnlyWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the buffer of this block, including header data.
- getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a buffer that does not include the header or checksum.
- getBuilder(WALCellCodec.ByteStringCompressor) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getBulkLoadDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
- getBulkLoadTimestamp() - Method in class 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
-
- getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the configured bytesPerChecksum value.
- getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getByteStringCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getByteStringUncompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCacheConfig() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Used for tests.
- getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getCachedBlockStatsByFile() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getCachedTime() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getCacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getCall() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- 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
-
- getCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getCatalogJanitorEnabled__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getCellPermissionsForUser(User, Cell) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- getCells() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getCellTTLColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getCellVisibilityColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the configured checksum algorithm.
- getChildExps() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getChildSequenceId(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
Parses sequenceId from the znode name.
- getChoreService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getChoreService() - Method in interface org.apache.hadoop.hbase.Server
-
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
- getClient() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getClient() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
If an RPC call is currently running, produces a String representation of
the connection from which it was received.
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- 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
-
- getClientVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getCloseCheckInterval() - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for closing region operations.
- getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getClosestRowBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return all the data for the row that matches row exactly,
or the one that immediately preceeds it, at or immediately before
ts.
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getClusterId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- 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.
- getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getClusterIds() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getCode() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getCodec(Configuration, String, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getCodec(Configuration, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getCodec(Configuration, Encryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodec(Configuration, Decryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.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.ExplicitColumnTracker
-
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Used by matcher and scan/get to get a hint of the next column
to seek to after checkColumn() returns SKIP.
- getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompaction(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.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
-
- getCompactionPolicy() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- 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
-
- getCompactionProgress() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
getter for CompactionProgress object
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
Returns the current size of the queue containing regions that are
processed.
- getCompactionRatio() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getCompactionRatioOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getCompactionRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCompactionState() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCompactionThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getCompactor() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- 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
-
- getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getCompletedSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a specified snapshot.
- getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a completed snapshot.
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
List the currently available/stored snapshots.
- getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Gets the list of all completed snapshots.
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getCompressionAlgorithm() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getConf() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- 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.master.balancer.BaseLoadBalancer
-
- getConf() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getConf() - Method in class org.apache.hadoop.hbase.tool.Canary
-
- getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- getConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfigurationManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Subclasses of HBaseServer can override this to provide their own
Connection implementations.
- getConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' cluster connection.
- getConnectionForEnvironment(CoprocessorEnvironment) - Static method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Create an unmanaged
HConnection
based on the environment in which we are running the
coprocessor.
- getConnectorAddress(int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the address that corresponds to a particular connector.
- getContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- getCoordinatedStateManager(Configuration) - Static method in class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
-
Creates consensus provider from the given configuration.
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCoordinatedStateManager() - Method in interface org.apache.hadoop.hbase.Server
-
Get CoordinatedStateManager instance for this server.
- getCoprocessorExecutionStatistics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getCoprocessorExecutionStatistics() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- 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 class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getCorruptedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getCurBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Needed for features such as delayed calls.
- getCurrentCompactedKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getCurrentFileName() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
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.DefaultWALProvider
-
return the current filename from the current wal.
- getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getCurrentHour() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- 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
-
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getCurrentPath() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the current log that's replicated
- 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.bucket.BucketCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- 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
-
- getCurTaskZKVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getDataBlockEncoder() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- 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.Region
-
- getDataSetWatchAsync() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getDataToWriteToZooKeeper(Map<String, Integer>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the labels data to be written to zookeeper.
- getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter data (the actual Bloom bits).
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- 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.regionserver.RSRpcServices
-
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getDeadServers(long) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Get the servers which died since a given timestamp.
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getDeadServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- 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
-
- getDefaultBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Get the default decoder for blocks from this file.
- getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
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.FSUtils
-
Returns the default buffer size to use during writes.
- getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
- getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
- getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
- getDefaultLoadBalancerClass() - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
- getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getDelegatesForTesting() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Exposed for TESTING!
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
- getDeletableFiles(Iterable<FileStatus>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Determines which of the given files are safe to delete
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- 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.HFileReaderV2
-
- getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.master_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.table_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.zk_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
-
- getDescription() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getDeserialiserIdentifier() - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Get the identifier of this deserialiser.
- getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
- getDeserializer(int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Get the cacheable deserializer as the given identifier Id
- getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- 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
-
Returns the configuration that was provided previously
- getDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDetailsForNonCoordinatedOpening() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Get details object with params for case when we're opening on
regionserver side with all "default" properties.
- getDetailsForNonCoordinatedOpening() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
No ZK tracking will be performed for that case.
- getDetaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Get details object with params for case when we're closing on
regionserver side internally (not because of RPC call from master),
so we don't parse details from protobuf request.
- getDetaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
No ZK tracking will be performed for that case.
- getDeterministicRandomSeed(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Creates a deterministic hash code for store file collection.
- getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDispersionInformation() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDummyHeaderForVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return the appropriate DUMMY_HEADER for the minor version
- getDumpServlet() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getDumpServlet() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getEarliestFlushTimeForAllStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getEarliestFlushTimeForAllStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getEarliestMemstoreSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getEarliestMemstoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getEarliestMemstoreSeqNum(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- getEarliestMemstoreSeqNum(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Gets the earliest sequence number in the memstore for this particular region and store.
- getEdit() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the edit
- getEffectiveDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getEffectiveDurability(Durability) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns effective durability from the passed durability and
the table descriptor.
- 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.HFileReaderV2
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Get the current thread local effective user
- getEncodedNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Gets the full path node name for the log file being split.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- 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
-
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEndKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEndRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the end row for a given stripe.
- getEndRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getEntryBuffer() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
- getErr() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- 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.HBaseFsck.ErrorReporter
-
- getErrorMonitor() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Get the ForeignExceptionDispatcher
- getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getEstimatedNumberOfKvsScanned() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Return the event type
- getEvictCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- 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.master.snapshot.TakeSnapshotHandler
-
- getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Get the last exception which has occurred when re-setting the watch.
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- 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
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getExecutorService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getExistingAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the favored nodes plan
- getExistingLabelsWithAuths() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getExpectedVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getFailedBlockAdditions() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getFailedDeletions() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getFamilies() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getFamily() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getFamily() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getFamilyArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- 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.TagRewriteCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getFavoredNodeList(String) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getFavoredNodes(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
- getFavoredNodesAsString(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- 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.master.balancer.FavoredNodeAssignmentHelper
-
- getFavoredServerPosition(List<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
Return the position of the server in the favoredNodes list.
- getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Exposed for Testing!
- 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.HFileReaderV2
-
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- getFileDetails(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Extracts some details about the files to compact that are commonly needed by compactors.
- getFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFileLinkWithPreNSPath(Path) - Method in class org.apache.hadoop.hbase.util.HFileV1Detector
-
Creates a FileLink which adds pre-namespace paths in its list of available paths.
- getFileList(Configuration, List<Path>, PathFilter) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Get a list of paths that need to be split given a set of server-specific directories and
optionally a filter.
- getFilename() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- getFilename() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getFileNumFromFileName(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
A log file has a creation timestamp (in ms) in its file name (
FSHLog.filenum
.
- getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Get the file permissions specified in the configuration, if they are
enabled.
- getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Get the backing files associated with this WAL.
- getFilesForScanOrGet(boolean, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the store files to scan for a Scan or Get request.
- getFilesForScanOrGet(boolean, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Get the FileStatus of the referenced file.
- getFileStatus() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilterEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
The number of Bloom filter entries in this store file, or an estimate
thereof, if the Bloom filter is not loaded.
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's
patch goes in to eliminate
KeyValue
here.
- getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- 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
-
On flush, how much memory we will clear.
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Get FlushPolicy class for the given table.
- getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getFrags() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFrags__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFreeBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- 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.bucket.BucketAllocator
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFromOnlineRegions(String) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
- getFs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the handle on the local file system
- 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.HFileReaderV2
-
Returns a buffer with the Bloom filter metadata.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- 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
-
- getGlobalLimiter() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Return the limiter associated with this quota.
- getGlobalMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGroupAuths(String[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getGroupAuths(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getGroupAuths(String[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the groups.
- getGroupAuthsAsOrdinals(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the groups
- getHashCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getHashType() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getHDFSBlocksDistribution() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getHeader() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getHeadPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the head of the linked list (least recently used).
- getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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
- 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
- getHFileMinorVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- 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.StoreFile.Reader
-
- getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHfs() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
- 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
-
- getHitCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the number of hits to the map.
- getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the hit ratio.
- getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getHostInetAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getHostname(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getHRegionInfo() - Method in interface org.apache.hadoop.hbase.master.handler.TotesHRegionInfo
-
- getHris() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getId() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- getInformativeName() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event implementations should override thie class to provide an
informative name about what event they are handling.
- getInformativeName() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getInitialCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- 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.
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance(int, int) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- getInstance() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getInstance(FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getIoEngine() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getIOHitsPerSecond() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIOTimePerHit() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getItemAllocationSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
Returns the full path to the Jar containing the class.
- GetJavaProperty - Class in org.apache.hadoop.hbase.util
-
A generic way for querying Java properties.
- GetJavaProperty() - Constructor for class org.apache.hadoop.hbase.util.GetJavaProperty
-
- getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the journal for the transaction.
- getJournal() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the journal for the transaction.
- getJournal() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current key.
- getKey() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the key of this entry.
- getKey() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the key
- getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getKeyForNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyForNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the key as a string - interpreting the
bytes as UTF8.
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getLabel(int) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
Returns the string associated with the ordinal.
- getLabel(int) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabelOrdinal(String) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
- getLabelOrdinal(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.ScanLabelGenerator
-
Helps to get a list of lables associated with an UGI
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getLabelsCount() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getLargeCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getLastCompactSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- 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.HFileReaderV2
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLastRecoveryTime() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- getLastRecoveryTime() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getLastRegionServerUpdate() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the timestamp at which the last change occurred to the list of region servers to replicate
to.
- getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after
Ryan's patch goes in to eliminate
KeyValue
here.
- getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastRowKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLeases() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- 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.ColumnCount
-
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- getLevel0Files() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- 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.quotas.RateLimiter
-
- getLimit() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getLimit__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getListener() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Return the socket (ip+port) on which the RPC server is listening to.
- getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLoadBalancer(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
Create a loadbalancer from the given conf.
- getLoadBalancerClassName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLoadedCachedBlocksByFile(Configuration, BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- 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.
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a LocalFileSystem within a HFileSystem.
- getLocalTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
-
- 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.
- 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.
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadLock
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessWriteLock
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLog(HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are stored by their RSs
- getLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getLogFileSize(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
iff the given WALFactory is using the BoundedRegionGroupingProvider for meta and/or non-meta,
count the size of files (rolled and active).
- getLogFileSize(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta,
count the size of files (rolled and active).
- getLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get log directory for a server in a snapshot.
- getLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLowestTimestamp(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets lowest timestamp from candidate StoreFiles
- getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMajorCompactionJitter() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorCompactionPeriod() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- 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.HFileReaderV2
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
- getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Get the application's mapper class.
- getMaster() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterAddressTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMasterConfiguration() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterProcedureExecutor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterQuotaManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterQuotaManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- getMasterRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
- getMasterServices() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the maximum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getMax() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMaxFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMaxFlushedSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMaxFlushedSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getMaxMasterTimeout(Configuration, HBaseProtos.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 interface org.apache.hadoop.hbase.regionserver.Store
-
- getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxMemstoreTSInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the largest memstoreTS found across all storefiles in
the given list.
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxRegions(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxSequenceIdInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the highest sequence ID found across all storefiles in
the given list.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the maximum size of this cache.
- getMaxSplitImbalance() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- 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
-
- getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getMean() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a List containing sum of values and sum of weights.
- getMemberName() - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Each subprocedure is being executed on a member.
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getMemFree() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently available memory for this LRU in bytes.
- getMemMax() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the maximum memory allowed for this LRU in bytes.
- getMemstoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemstoreFlushSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently used memory for this LRU in bytes.
- getMergedRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
- getMergedRegionInfo(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Get merged region info through the specified two regions
- getMergedRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getMergeThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- 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.HFileReaderV2
-
- getMetadataValue(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Only used by the Striped Compaction Policy
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getMetaLocation() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaLocation__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getMetaTableLocator() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetaTableLocator() - Method in interface org.apache.hadoop.hbase.Server
-
- getMetaWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter meta data.
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- 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 class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMetrics() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- 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.MetricsRegionServer
-
- getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the minimum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getMin() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMinCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMinIndexNumEntries(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMinLocalityToForceCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- 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.HFileWriterV2
-
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- 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.regionserver.LruHashMap
-
Get the number of misses to the map.
- getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMode() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- getModificationTime() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getModificationTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMonitor() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- getMostLoadedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the top N most loaded regions this server is serving so we can tell the
master which regions it can reallocate if we're overloaded.
- getMTime() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- getMutationsFromWALEntry(AdminProtos.WALEntry, CellScanner, Pair<WALKey, WALEdit>, Durability) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
This function is used to construct mutations from a WALEntry.
- getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMvccVersion() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getMWrap() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- 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 class org.apache.hadoop.hbase.client.HTableWrapper
-
- getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getName() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- 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.procedure.Procedure
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getName() - Method in exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
-
- getName() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Human readable name of the processor
- getName() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNamespace() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get a namespace descriptor by name
- getNamespaceDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the Path
object representing
the namespace directory under path rootdir
- getNamespaceLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified namespace.
- getNamespaceQuotaManager() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- getNewAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getNextBlockOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- 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.StoreFileScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getNextMajorCompactTime(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- getNextPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Poll for the next path
- getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the next pointer for the entry in teh LRU.
- getNextQueue() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.QueueBalancer
-
- 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
-
- getNextRowOrNextColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Retrieve the MatchCode for the next row or column
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- getNextSequenceId(WAL) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Method to safely get the next sequence number.
- getNextSleepInterval(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Get how long the caller should sleep according to the current size and
current cycle's total push size and start tick, return the sleep interval
for throttling control.
- getNoChecksumFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the filesystem that is specially setup for
doing reads from storage.
- getNonce() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- 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.
- getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- 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 class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumChunks() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumCompactionsCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getNumDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumFilesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getNumLogFiles(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
iff the given WALFactory is using the BoundedRegionGroupingProvider for meta and/or non-meta,
count the number of files (rolled and active).
- getNumLogFiles(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta,
count the number of files (rolled and active).
- getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getNumObservers() - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumRegions() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumRegionsOpened() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by unit tests.
- getNumRolledLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getNumRolledLogFiles(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
returns the number of rolled WAL files.
- getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getOffPeakHours() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- 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
-
- getOffset() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- 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
-
- getOldestSeqIdOfStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getOldLogDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Get the directory where old logs go
- getOldLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are archived
- getOldSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the old sources of this rs
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOnDiskSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getOnlineRegions(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online regions of the specified table.
- getOnlineRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions of a table in this RS.
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- 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
-
- getOnlineServers() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Gets the online servers.
- getOnlineServersList() - 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.
- getOnlineTables() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for opening region operations.
- getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOpenSeqNum() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- getOperator() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getOriginatingClusterId() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Return a positive long if current WALKey is created from a replay edit
- 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.WALSplitter.OutputSink
-
- getOverlapGroups(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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.security.access.AuthResult
-
- 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
-
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Return the 'path' component of a Path.
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
- getPeerClusterId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to.
- getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterZnode() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the slave peer ID
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- 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.security.visibility.VisibilityReplicationEndpoint
-
- getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
-
- getPhase() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
-
- getPhase() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- getPort() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- getPort() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Deprecated.
- 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
-
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Get the position that we stopped reading at
- getPosition() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- getPreAssignedWriteNumber(AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Get a mvcc write number before an actual one(its log sequence Id) being assigned
- getPrevBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the previous pointer for the entry in the LRU.
- getPrimaryHRIForDeployedReplica() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- 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.coprocessor.CoprocessorHost.Environment
-
- getPriority() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Get the priority level for this handler instance.
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getPriority(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the 'priority type' of the specified request.
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the priority for the request
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- 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
-
- getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns the procedure.
- getProcedureManager(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- getProcedureManagers() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- getProcedureQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
-
Return the unique signature of the procedure.
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- getProcessName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProcessName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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
-
- getProgress() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- getProgressPct() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
getter for calculated percent complete
- getQualifiedPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getQualifier() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getQualifierArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the length of the pending queue
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the list of request queues
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getQuota(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Returns the quota for an operation.
- 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.
- getRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.RackManager
-
- getReachedBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getReachedBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
execution and release on each subprocedure.
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getReader(FileStatus, boolean, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReader(Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReadpoint(IsolationLevel) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadpoint(IsolationLevel) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getRealCacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getReason() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- 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
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- 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.
- getRecoveringRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRecoveringRegions() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRecoveryMode() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Temporary function, mostly for UTs.
- getRecoveryMode() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getRecoveryMode() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- getReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- 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
-
- getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Protected utility method for safely obtaining an HRegion handle.
- getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getRegion() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- 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
- 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
- getRegionAssignments() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionAssignmentsByServer(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getRegionAssignmentsByServer() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Returns a clone of region assignments per server
- getRegionAssignmentSnapshot() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getRegionBlockLocations(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByEncodedName(byte[], String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByStateOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Gets current state of all regions of the table.
- 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
-
- 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(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- getRegionDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- 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
- getRegionEventDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionFlushedSequenceId(String, String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
- getRegionFlushedSequenceId(String, String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getRegionFlushedSequenceId(ZooKeeperWatcher, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
This function is used in distributedLogReplay to fetch last flushed sequence id from ZK
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get the HRegionInfo from cache, if not there, from the hbase:meta table
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getRegionInfoForFS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionInfoForFs(HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns the regionInfo object to use for interacting with the file system.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getRegionLocator(byte[]) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Retrieve a regionLocator for the table.
- 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.
- getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for region merge transaction
- getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- 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.regionserver.MetricsRegionWrapperImpl
-
- getRegionName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegionNameToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the regioninfo for a region
- getRegionReferenceFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionReopenPlan(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getRegionReplicaStoreFileRefreshMultiplier(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- 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
-
- getRegionServerInfo(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
- getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerOfRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionServerQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get a list of all the addresses of all the region servers
for this peer cluster
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Gets the region server services.
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the RegonServerServices of the server running the transaction or rollback
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the RegonServerServices of the server running the transaction or rollback
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- getRegionServerToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regionserver to region map
- getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getRegionsFromMeta(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- getRegionsFromMeta() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get regions in transition and their states
- 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.util.RegionSizeCalculator
-
Returns size of given region in bytes.
- getRegionSizeMap() - Method in class org.apache.hadoop.hbase.util.RegionSizeCalculator
-
- 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
- getRegionsOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Gets the online regions of the specified table.
- getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionStates() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
This SHOULD not be public.
- getRegionStats() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- 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
- getRegionTransitionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get region transition state
- getRegionTransitionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get region transition state
- getRegionWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- getRemoteAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- 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 class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getRemoteUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRenewer() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getReopenStatus(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by the client to identify if all regions have the schema updates
- getReplicaId() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getReplicasToClose() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Get the replication sources manager
- getReplicationPeer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getReplicationPeerId() - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Return the peer id used for replicating to secondary region replicas
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- 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
-
- getReplicationSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Get a randomly-chosen replication sink to replicate to.
- getReplicationSource(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationPeerConfig, ReplicationPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Factory method to create a replication source
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- getRequest() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- 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 class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRequestData() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
This method should return any additional data that is needed on the
server side to construct the RowProcessor.
- getRequestLog(String) - Static method in class org.apache.hadoop.hbase.http.HttpRequestLog
-
- 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
null
if no credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the user credentials associated with the current RPC request or
null
if no credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getRequestUserName() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getRequestUserName() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the username for any user associated with the current RPC
request or null
if no user is set.
- getRescanNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Obtain the processing result.
- getRetainDays() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- getRow() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getRowArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getRowKeyAtOrBefore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Find the key that matches row exactly, or the one that immediately precedes it.
- getRowKeyAtOrBefore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Find the key that matches row exactly, or the one that immediately precedes it.
- getRowKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getRowLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowLock(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Acquires a lock on the given row.
- getRowLock(byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Tries to acquire a lock on the given row.
- getRowLockInternal(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
A version of getRowLock(byte[], boolean) to use when a region operation has already been
started (the calling thread has already acquired the region-close-guard lock).
- getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the row count for the given column family and column qualifier, in
the given row range as defined in the Scan object.
- getRowOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
Deprecated.
- getRowProcessorPB(RowProcessor<S, T>) - Static method in class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
-
- getRowsToLock() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Rows to lock while operation.
- getRPC() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPC(boolean) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPCPacketLength() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCPacketLength() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPCQueueTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCQueueTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the queue time for the currently running RPC on the
monitored Handler.
- getRpcServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns a reference to the region server's RPC server
- getRPCStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the start time for the currently running RPC on the
monitored Handler.
- getRSRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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.TableSplit
-
Returns a Scan object from the stored string representation.
- getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getScanInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getScanLabelGenerators(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
Create a Scanner on this file.
- getScanner() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getScanner() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- 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, NavigableSet<byte[]>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Return a scanner for both the memstore and the HStore files.
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - 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 interface org.apache.hadoop.hbase.regionserver.MemStore
-
- getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Get all scanners with no filtering based on TTL (that happens further down
the line).
- getScannersForStoreFiles(Collection<StoreFile>, 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<StoreFile>, 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<StoreFile>, 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
- getScannersNoCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Get a filtered list of scanners.
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- 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.
- getScheme(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getSchemePrefix() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getScopes() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking the scope.
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getSelectionTime() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- getSeqid() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
MemStoreScanner returns max value as sequence id because it will
always have the latest data among all files.
- getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Do not change this sequence id.
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getSequenceID() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Get the sequence id associated with this KeyValueScanner.
- getSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.SequenceId
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
-
Returns the original sequence id
- getSequenceId() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getSequenceId(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Wait for sequence number to be assigned & return the assigned value.
- 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
-
- getSerializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getServer() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
- getServer() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- getServer() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the Server running the transaction or rollback
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getServer() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the Server running the transaction or rollback
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- 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
-
- getServerManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerName() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
-
- getServerName() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getServerName() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- 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 class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
- getServerName() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- getServerNameFromWALDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
Pulls a ServerName out of a Path generated according to our layout rules.
- getServerNameFromWALDirectoryName(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
This function returns region server name from a log file name which is in one of the following
formats:
hdfs:///hbase/.logs/-splitting/...
- getServerRegions(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get a copy of all regions assigned to a server
- getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.CoprocessorService
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.SingletonCoprocessorService
-
- getService() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getService() - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- getService() - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getServiceInterface() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- getServices() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getServices() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getShortHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
- getSinkMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get replication Sink Metrics
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getSize() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the total size of all StoreFiles in compaction
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getSize() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the sizeOfLogQueue
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- 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
-
- getSkipReplayedEditsFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSmallCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- 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 class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- 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
- getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotManagerForTesting() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Exposed for TESTING!
- getSnapShotOfAssignment(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the snapshot root directory.
- getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- 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 the memstore snapshot size
- getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSocketAddress() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- 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.
- getSourceMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Get Replication Source Metrics
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the normal sources of this rs
- getSplitCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Returns sorted set of edit files made by splitter, excluding files
with '.temp' suffix.
- getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getSplitKey(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
select a split point in the region.
- getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitLogDirTmpComponent(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split log manager
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split log worker
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getSplitPartSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Determines if Store should be split
- 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
-
- getSplitPolicy() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getSplitPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- 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.HLogInputFormat
-
Deprecated.
- 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.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(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getSplitSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split transaction.
- getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getStartcode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getStartKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the start row.
- getStartRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the start row for a given stripe.
- 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.master.MetricsMasterWrapperImpl
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStateId(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getStateId(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getStateId(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getStateId(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getStateId(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getStateId(MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- 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.bucket.BucketCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- 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.regionserver.wal.WALEditsReplaySink
-
Get a string representation of this sink's metrics
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get a string representation of this sink's metrics
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getStats() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get a string representation of the current statistics
for this source
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a string representation of all the sources' metrics
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gets the status of this handler; if it is currently servicing an RPC,
this status will include the RPC information.
- getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatus() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a Pair with first object a List containing Sum and sum of squares,
and the second object as row count.
- getStdDev() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- 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, TableName, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreCompactionPriority() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- 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(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- 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
-
- getStoreFileInfo(Configuration, FileSystem, HRegionInfo, HRegionInfo, String, Path) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns a StoreFileInfo from the given FileStatus.
- getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStoreFileList(byte[][]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStoreFiles(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getStoreFiles(String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- 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
-
- getStoreFileScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Get a scanner to scan over this StoreFile.
- getStoreFileScanner(boolean, boolean, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
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
-
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStorefilesIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getStoreHomedir(Path, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Deprecated.
- getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Deprecated.
- getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- 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
- getStoreSizeUncompressed() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreSizeUncompressed() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStream(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Get the stream to use.
- getStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getStripeBoundaries() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- 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 interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStripeCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStripes() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStripes() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the sum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- 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
-
- 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
-
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Get names of supported compression algorithms.
- getTable(TableName) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- getTable(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- 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
-
- 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(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller closes the table afterwards.
- 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.
- 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.
- getTableCfWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking replication per table and CF.
- getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getTableDesc() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Gets a TableDescriptor from the masterServices.
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the table descriptor from the Snapshot
- 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.
- getTableDescriptorFromFs(FileSystem, Path, TableName, boolean) - 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) - 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, boolean) - 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.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of TableDescriptors for requested tables.
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the Path
object representing the table directory under
path rootdir
- getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- 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.
- 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.
- getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
- getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- getTableInfoPath(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Find the most current table info file for the table located in the given table directory.
- 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.
- getTableLockManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableLockManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getTableLockManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- 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.master.procedure.AddColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableName() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the
TableName
object representing
the table directory under
path rootdir
- getTableName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getTablename() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getTableName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of userspace table names
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
Given an operation type we can take decisions about what to do with pending operations.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableSet() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the table set
- getTablesInStates(ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- getTablesInStates(ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Gets a list of all the tables set as disabling in zookeeper.
- getTablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getTableStateManager() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Returns implementation of TableStateManager.
- getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getTableStateManager() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- 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, HBaseFsck.ErrorReporter) - 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(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, HBaseFsck.ErrorReporter) - 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.
- getTableToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regions for tables
- getTagsArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTailKbParam(HttpServletRequest) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- getTailPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the tail of the linked list (most recently used).
- getTaskMonitor() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTaskMonitor__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTaskNode() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getTaskReadySeq() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
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
-
Returns the number of tasks processed by coordination.
- getTasks() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Produces a list containing copies of the current state of all non-expired
MonitoredTasks handled by this TaskMonitor.
- getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Configuration knobs "hbase.bulk.reopen.threadpool.size" number of regions
that can be reopened concurrently.
- getThreadInfo(Thread) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getThreadWakeFrequency() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Interval at which threads should run
- getThrottlePoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- getTimeOfDeath(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Get the time when a server died
- getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTimestampKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getTimeStampOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the TimeStampOfLastAppliedOp.
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the timeStampsOfLastShippedOp
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTimeUnitInMillis() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- 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
- getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getTotalCompactedSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getTotalCompactingKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getTotalFileSize(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- getTotalQueueSize() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getTotalSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- 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.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.
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- 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.
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getUnblockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getUnneededFiles(long, List<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getUnneededFiles(long, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getUnreferencedFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Check to see if any of the passed file names is contained in any of the snapshots.
- getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- 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.
- getUsedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getUsedSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getUserAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getUserAuths(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getUserAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the user.
- getUserAuthsAsOrdinals(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the user
- getUserAuthsDataToWriteToZooKeeper(Map<String, List<Integer>>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the user auth data to be written to zookeeper.
- getUserFromPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getUserLimiter(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified user/table.
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getUserProvider() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getUserQuotaState(UserGroupInformation) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the QuotaState associated to the specified user.
- getUserToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current value.
- getValue() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the value of this entry.
- getValue() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getValueArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the value as a string - interpreting
the bytes as UTF8.
- getVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- getVersion() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
- getVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- getVisibilityExpEvaluator(Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getVisibilityExpEvaluator(Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates VisibilityExpEvaluator corresponding to given Authorizations.
- getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- getVisibilityLabelService(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getVisibilityLabelService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- 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
-
- getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWAL(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWAL(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- getWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getWAL(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
- getWALActionsListener() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns a WALObserver for the service.
- getWALActionsListener() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getWALDirectoryName(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
Construct the directory name for all WALs on a given server.
- getWalEdit(int) - 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 class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- 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.security.visibility.VisibilityReplicationEndpoint
-
- getWALFile() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
-
- getWALFile() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getWALNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the log file names available in the snapshot.
- getWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the first source on this rs
- getWalsByIdRecoveredQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the recovered sources on this rs
- getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- 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(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
- getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getWorkingSnapshotDir(Path) - 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(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWorkingSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
-
Provide a size hint to the caller.
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- 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.
- getWriteTime() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- getZkw() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the ZK connection to this peer
- getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
-
- getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- grabQuota(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes the specified write and read amount from the quota.
- grabQuota(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- 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.
- groupHasAccess(String, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
- GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
-
Extract grouping columns from input record
- GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Extract grouping columns from input record.
- GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
- groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, Table, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Attempt to assign the given load queue item into its target region group.
- 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(FileSystem, Path, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a normal hfile.
- HalfStoreFileReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a hfile referred to by an hfilelink.
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
- handleCoprocessorThrowable(CoprocessorEnvironment, 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).
- handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Create the on-disk structure for the table, and returns the regions info.
- handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region that has the same start and end key.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region that has the same start and end key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two regions that have the same start key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two regions that have the same start key.
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event exception handler, may be overridden
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
-
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- 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.
- handleLockMetadata(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Process metadata stored in a ZNode using a callback
- handleLockMetadata(String, InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Process metadata stored in a ZNode using a callback object passed to
this instance.
- handleMetadata(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessLock.MetadataHandler
-
Called after lock metadata is successfully read from a distributed
lock service.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling an group of regions that overlap.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling an group of regions that overlap.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two reigons that overlap in some arbitrary way.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two reigons that overlap in some arbitrary way.
- handler - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- 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(HBaseFsck.HbckInfo) - 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(HBaseFsck.HbckInfo) - 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.
- handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TruncateTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
The restore table is executed in place.
- has(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Check to see if the Constraint is currently set.
- hasAccess(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- 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.
- hasAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- hasCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- hasError() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- hasException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Check if an exception has occurred when re-setting the watch.
- hasFamilyStamp - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- hasFreeSpace() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The hash value for this entries key
- hash - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash Function
- HASH_NONCE_GRACE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- 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.HFile.FileInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.Reference
-
- 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.balancer.FavoredNodesPlan
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- hashCode() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the hash code of the entry by xor'ing the hash values
of the key and value of this entry.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- hashCode() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- hashCode() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- hashCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Number of hash functions
- 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
-
- hashType - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash type
- hashType - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Hash function type to use, as defined in
Hash
- hasMinimumVersion(RPCProtos.VersionInfo, int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
- hasMoreValues() - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- hasMoreValues(ScannerContext.NextState) - Static method in enum 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.HFileReaderV2
-
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- hasPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- hasProcedureSupport() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hasReferences(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns true if the specified family has reference files
- hasReferences(HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Check whether region has Reference file
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- hasReferences() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- hasReferences(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Determines whether any files in the collection are references.
- hasRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- hasTagCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- hasTooManyStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- havingSystemAuth(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
Deprecated.
- havingSystemAuth(User) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- havingSystemAuth(byte[]) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
- havingSystemAuth(User) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System checks for user auth during admin operations.
- 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_FLUSH_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
- HBASE_HSTORE_COMPACTION_MAX_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_HIGHER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_OFFPEAK - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MIN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MIN_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_RATIO_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_MIN_LOCALITY_TO_SKIP_MAJOR_COMPACT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_OFFPEAK_END_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_OFFPEAK_START_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
- HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
Enable/Disable aliases serving from jetty
- 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_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Enable or disable snapshot support
- 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_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- HBaseConfTool - Class in org.apache.hadoop.hbase.util
-
Tool that prints out a configuration.
- HBaseConfTool() - Constructor for class org.apache.hadoop.hbase.util.HBaseConfTool
-
- HBaseFsck - Class in org.apache.hadoop.hbase.util
-
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
- HBaseFsck(Configuration) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseFsck(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseFsck.ErrorReporter - Interface in org.apache.hadoop.hbase.util
-
- HBaseFsck.ErrorReporter.ERROR_CODE - Enum in org.apache.hadoop.hbase.util
-
- HBaseFsck.HbckInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular region.
- HBaseFsck.RegionRepairException - Exception in org.apache.hadoop.hbase.util
-
Exception thrown when a integrity repair operation fails in an
unresolvable way.
- HBaseFsck.RegionRepairException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.util.HBaseFsck.RegionRepairException
-
- HBaseFsck.TableInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular table.
- 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
-
- HBaseInterClusterReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
-
- HBaseInterClusterReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- 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
-
- HBaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
-
- HBaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- HBaseReplicationEndpoint.PeerRegionServerListener - Class in org.apache.hadoop.hbase.replication
-
Tracks changes to the list of region servers in a peer's cluster.
- HBaseReplicationEndpoint.PeerRegionServerListener(HBaseReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
-
- HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
-
An interface for calling out of RPC for error conditions.
- HBaseSaslRpcServer - Class in org.apache.hadoop.hbase.security
-
A utility class for dealing with SASL on RPC server
- HBaseSaslRpcServer() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- HBaseSaslRpcServer.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL DIGEST-MD5 mechanism
- HBaseSaslRpcServer.SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, RpcServer.Connection) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
-
- HBaseSaslRpcServer.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL GSSAPI Kerberos mechanism
- HBaseSaslRpcServer.SaslGssCallbackHandler() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
-
- HBCK_CODE_SERVERNAME - Static variable in class org.apache.hadoop.hbase.master.AssignmentManager
-
- 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
-
Constructor
- HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
-
Stores the hostname and weight for that hostname.
- HDFSBlocksDistribution.HostAndWeight(String, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Constructor
- HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
-
comparator used to sort hosts based on weight
- HDFSBlocksDistribution.HostAndWeight.WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- header - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- 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.HFile.FileInfo
-
- headSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- headSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- headSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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
-
- HeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
-
Manages tuning of Heap memory using HeapMemoryTuner
.
- HeapMemoryManager.TunerContext - Class in org.apache.hadoop.hbase.regionserver
-
POJO to pass all the relevant information required to do the heap memory tuning.
- HeapMemoryManager.TunerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- HeapMemoryManager.TunerResult - Class in org.apache.hadoop.hbase.regionserver
-
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
- HeapMemoryManager.TunerResult(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- HeapMemoryTuner - Interface in org.apache.hadoop.hbase.regionserver
-
Makes the decision regarding proper sizing of the heap memory.
- HeapMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- HeapMemStoreLAB() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
- HeapMemStoreLAB(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
- 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.bucket.BucketCache
-
- 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.HFileBlockIndex.BlockIndexReader
-
- 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.regionserver.DefaultMemStore
-
Get the entire heap usage for this MemStore not including keys in the
snapshot.
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The precomputed heap size of this entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the pre-computed and "deep" size of the Entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
The total memory usage of this map
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- heapSize() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- heapSize() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- heartbeat(long, int, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- heartbeatNoDetails(long) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- HFile - Class in org.apache.hadoop.hbase.io.hfile
-
File format for hbase.
- HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
-
- HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
-
An abstraction used by the block index.
- HFile.FileInfo - Class in org.apache.hadoop.hbase.io.hfile
-
Metadata for this file.
- HFile.FileInfo() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- HFile.Reader - Interface in org.apache.hadoop.hbase.io.hfile
-
An interface used by clients to open and iterate an
HFile
.
- HFile.Writer - Interface in org.apache.hadoop.hbase.io.hfile
-
API required to write an
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.
- HFILE_ARCHIVE_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- HFILE_CACHE_REFRESH_PERIOD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Conf key for the frequency to attempt to refresh the cache of hfiles currently used in
snapshots (ms)
- 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.
- HFileArchiver - Class in org.apache.hadoop.hbase.backup
-
Utility class to handle the removal of HFiles (or the respective
StoreFiles
)
for a HRegion from the
FileSystem
.
- HFileArchiveTableMonitor - Class in org.apache.hadoop.hbase.backup.example
-
Monitor the actual tables for which HFiles are archived for long-term retention (always kept
unless ZK state changes).
- HFileArchiveTableMonitor() - Constructor for class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- HFileArchiveUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for all utilities related to archival/retrieval of HFiles
- HFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
Reading
HFile
version 1 and 2 blocks, and writing version 2 blocks.
- HFileBlock.BlockIterator - Interface in org.apache.hadoop.hbase.io.hfile
-
- HFileBlock.BlockWritable - Interface in org.apache.hadoop.hbase.io.hfile
-
Something that can be written into a block.
- HFileBlock.FSReader - Interface in org.apache.hadoop.hbase.io.hfile
-
A full-fledged reader with iteration ability.
- HFileBlock.Writer - Class in org.apache.hadoop.hbase.io.hfile
-
Unified version 2
HFile
block writer.
- HFileBlock.Writer(HFileDataBlockEncoder, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- HFileBlock.Writer.BufferGrabbingByteArrayOutputStream - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileBlock.Writer.BufferGrabbingByteArrayOutputStream() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileBlockIndex() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- HFileBlockIndex.BlockIndexReader - Class in org.apache.hadoop.hbase.io.hfile
-
The reader will always hold the root level index in the memory.
- HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Writes the block index into the output stream.
- HFileBlockIndex.BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a single-level block index writer
- HFileBlockIndex.BlockIndexWriter(HFileBlock.Writer, CacheConfig, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a multi-level block index writer.
- HFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
This Chore, every time it runs, will clear the HFiles in the hfile archive
folder that are deletable for each HFile cleaner in the chain.
- HFileCleaner(int, Stoppable, Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- hFileContext - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- 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
-
- HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
-
Controls what kind of data block encoding is used.
- 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.
- HFileLink - Class in org.apache.hadoop.hbase.io
-
HFileLink describes a link to an hfile.
- HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
-
Dead simple hfile link constructor
- HFileLinkCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
HFileLink cleaner that determines if a hfile should be deleted.
- HFileLinkCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
-
Writes HFiles.
- HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- 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
-
- HFileReaderV2 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 2.
- HFileReaderV2(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Opens a HFile.
- HFileReaderV2.AbstractScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.AbstractScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- HFileReaderV2.EncodedScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
ScannerV2 that operates on encoded data blocks.
- HFileReaderV2.EncodedScannerV2(HFileReaderV2, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- HFileReaderV2.ScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.ScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- HFileReaderV3 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 3.
- HFileReaderV3(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
Opens a HFile.
- HFileReaderV3.EncodedScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
-
ScannerV3 that operates on encoded data blocks.
- HFileReaderV3.EncodedScannerV3(HFileReaderV3, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.EncodedScannerV3
-
- HFileReaderV3.ScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV3.ScannerV3(HFileReaderV3, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
-
A scanner allows you to position yourself within a HFile and
scan through it.
- HFileSystem - Class in org.apache.hadoop.hbase.fs
-
An encapsulation for the FileSystem object that hbase uses to access
data.
- HFileSystem(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a FileSystem object for HBase regionservers.
- HFileSystem(FileSystem) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a FileSystem object within a HFileSystem.
- HFileV1Detector - Class in org.apache.hadoop.hbase.util
-
Tool to detect presence of any HFileV1 in the given directory.
- HFileV1Detector() - Constructor for class org.apache.hadoop.hbase.util.HFileV1Detector
-
- HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
-
Writes HFile format version 2.
- HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Constructor that takes a path, creates and closes the output stream.
- HFileWriterV3 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
writer for version 3.
- HFileWriterV3(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
Constructor that takes a path, creates and closes the output stream.
- hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
The filesystem used for accesing data
- higher(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- hit(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
-
- HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogKey(byte[], TableName, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Deprecated.
use the "hbase wal" command
- HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Deprecated.
Basic constructor that simply initializes values to reasonable defaults.
- HLogPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Deprecated.
Fully specified constructor.
- HMaster - Class in org.apache.hadoop.hbase.master
-
HMaster is the "master server" for HBase.
- HMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMaster
-
Initializes the HMaster.
- HMaster.RedirectServlet - Class in org.apache.hadoop.hbase.master
-
- HMaster.RedirectServlet() - Constructor for class org.apache.hadoop.hbase.master.HMaster.RedirectServlet
-
- HMasterCommandLine - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine(Class<? extends HMaster>) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- HMasterCommandLine.LocalHMaster - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine.LocalHMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- hMemManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- hostAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- hostName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Set the hostname of the http server.
- HRegion - Class in org.apache.hadoop.hbase.regionserver
-
- HRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- HRegion(HRegionFileSystem, WAL, Configuration, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
HRegion constructor.
- 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.
- HRegion.RowLockImpl - Class in org.apache.hadoop.hbase.regionserver
-
- HRegion.RowLockImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
-
View to an on-disk Region.
- HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
-
This is used to partition the output keys into groups of keys.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- 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.mapreduce.HRegionPartitioner
-
- 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.
- HRegionServer(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Starts a HRegionServer at the default location
- HRegionServer.MovedRegionsCleaner - Class in org.apache.hadoop.hbase.regionserver
-
Creates a Chore thread to clean the moved region cache.
- 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
-
- HStore - Class in org.apache.hadoop.hbase.regionserver
-
A Store holds a column family in a Region.
- HStore(HRegion, HColumnDescriptor, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
-
Constructor
- hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- HTableWrapper - Class in org.apache.hadoop.hbase.client
-
A wrapper for HTable.
- htd - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- HtmlQuoting - Class in org.apache.hadoop.hbase.http
-
This class is responsible for quoting HTML characters.
- HtmlQuoting() - Constructor for class org.apache.hadoop.hbase.http.HtmlQuoting
-
- 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
-
- HttpConfig.Policy - Enum in org.apache.hadoop.hbase.http
-
- HttpRequestLog - Class in org.apache.hadoop.hbase.http
-
RequestLog object for use with Http
- HttpRequestLog() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLog
-
- HttpRequestLogAppender - Class in org.apache.hadoop.hbase.http
-
Log4j Appender adapter for HttpRequestLog
- HttpRequestLogAppender() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- 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.
- HttpServer(String, String, int, boolean, Configuration, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer.Builder - Class in org.apache.hadoop.hbase.http
-
Class to construct instances of HTTP server with specific options.
- HttpServer.Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- 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.
- HttpServer.QuotingInputFilter() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.hbase.http
-
- HttpServer.QuotingInputFilter.RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- HttpServer.StackServlet - Class in org.apache.hadoop.hbase.http
-
A very simple servlet to serve up a text representation of the current
stack traces.
- HttpServer.StackServlet() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.StackServlet
-
- HttpServerUtil - Class in org.apache.hadoop.hbase.util
-
HttpServer utility.
- HttpServerUtil() - Constructor for class org.apache.hadoop.hbase.util.HttpServerUtil
-
- id - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- idealMaxKeys(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
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).
- 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
- 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
-
- 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
-
- IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Convenience class that simply writes all values (which must be
Put
or
Delete
instances)
passed to it out to the configured HBase table.
- IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
- 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
-
- IdLock.Entry - Class in org.apache.hadoop.hbase.util
-
An entry returned to the client as a lock object
- ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Generates an immediate assignment plan to be used by a new master for
regions in transition that do not have an already known destination.
- immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Sync assign a region
- impl - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
The coprocessor
- Import - Class in org.apache.hadoop.hbase.mapreduce
-
Import data written by
Export
.
- Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
-
- Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- Import.Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- Import.KeyValueImporter - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that just writes out KeyValues.
- Import.KeyValueImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
- IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- 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
-
- ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
-
- ImportTsv.TsvParser(String, String) - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
-
- ImportTsv.TsvParser.BadTsvLineException(String) - Constructor for exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
-
- incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- 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.
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Check if the range has any overlap with TimeRange
- includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- includeTimestamp(Cell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from Cell
If the Key is of type DeleteColumn or DeleteFamily, it includes the
entire time range from 0 to timestamp of the key.
- InclusiveCombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- InclusiveCombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- 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(Increment) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- increment() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Increment the current version count
- increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment(Increment, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more increment operations on a row.
- 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
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Add on the number of log edits filtered
- incrLogEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
The number of log edits filtered out.
- incrLogEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Increment the number of log edits read by one.
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
increase the byte number read by source from log file
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- indexSize() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- 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.
- infoServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- init() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Support method to init constants such as timeout.
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Initialize internal values.
- init() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Initialize this servlet.
- 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(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() - 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.migration.NamespaceUpgrade
-
- init(StoreScanner, StripeMultiFileWriter.WriterFactory, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Initializes multi-writer before usage.
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Instantiation method used by region servers
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Initializer for the source
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Adds a normal source per registered peer cluster and tries to process all
old region server wal queues
- init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initialize the replication endpoint with the given context.
- init(Configuration, ServiceAuthorizationManager) - Static method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- init(Configuration) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- init(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- init(RegionCoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System calls this after opening of regions.
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Reader
-
- init(FileSystem, Path, Configuration, boolean) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Writer
-
- init(byte[], TableName, long, long, List<UUID>, long, long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Set up the provider to create wals.
- initAdmin() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- initCosts(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- 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, String) - 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.
- 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.StaticUserWebFilter
-
- 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.master.CatalogJanitor
-
- initialize(Server) - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Initialize coordinated state management service.
- initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- 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(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(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(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Initialize the load balancer.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Initialize the region assignment snapshot by scanning the hbase:meta table
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Initialize this region server flush procedure manager
Uses a zookeeper based member controller.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Initialize a globally barriered procedure for master.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Initialize a globally barriered procedure for region servers.
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
use HRegion.createHRegion() or HRegion.openHRegion()
- initialize(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Initializes the memstoreRead/Write points appropriately.
- initialize(Server, FileSystem, Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Initializes the replication service object.
- initialize(S) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
This method should initialize any field(s) of the RowProcessor with
a parsing of the passed message bytes (used on the server side).
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Create a default snapshot handler - uses a zookeeper based member controller.
- initialize(Server, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- initializeCompressionContext(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- initialized - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- initializeQueues(int, Class<? extends BlockingQueue>, Object...) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- 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.
- 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, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
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.
- initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Use this before submitting a TableMap job.
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the log reader with a particular stream (may be null).
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- 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(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(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.
- 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(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(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(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(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(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(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.
- 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, String, String) - 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, String, String, 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.
- 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.
- InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
-
A way to write "inline" blocks into an
HFile
.
- INPUT_AUTOBALANCE_MAXSKEWRATIO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Specify if ratio for data skew in M/R jobs, it goes well with the enabling hbase.mapreduce
.input.autobalance property.
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- insertNewFiles(Collection<StoreFile>) - 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<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should act with the assumption that the barrier condition
has been satisfied.
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
do a flush snapshot of every region on this rs from the target table.
- 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
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- instantiateBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache or null
in case none should be used.
- 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(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateRegionScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalClose() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- internalFlushcache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the memstore.
- internalFlushCacheAndCommit(WAL, MonitoredTask, HRegion.PrepareFlushResult, Collection<Store>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalPrepareFlushCache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- 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
-
- 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.
- InterProcessLock - Interface in org.apache.hadoop.hbase
-
An interface for an application-specific lock.
- InterProcessLock.MetadataHandler - Interface in org.apache.hadoop.hbase
-
An interface for objects that process lock metadata.
- InterProcessReadWriteLock - Interface in org.apache.hadoop.hbase
-
An interface for a distributed reader-writer lock.
- interrupt() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- 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
- 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 index i
,
create a new array with the corresponding inverted indices.
- 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
- IOEngine - Interface in org.apache.hadoop.hbase.io.hfile.bucket
-
A class implementing IOEngine interface supports data services for
BucketCache
.
- ioHit(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- isAbortPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier abort znode path
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is currently the active master or not.
- isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Test for the availability of the web server
- isAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isAllowed() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- isAppendSupported(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Heuristic to determine whether is safe or not to open a file for append
Looks both for dfs.support.append and use reflection to search
for SequenceFile.Writer.syncFs() or FSDataOutputStream.hflush()
- isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isAvailable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- 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 is known to be unstable.
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Return true if the balance switch is on, false otherwise
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Checks whether the block cache is enabled.
- isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- isBypass() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- 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
-
- isCacheDataInL1() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCarryingMetaReplica(ServerName, int) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCarryingMetaReplica(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- 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.
- isChildOfSameType(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents the same type(read or write) of lock
- isChildReadLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents a read lock.
- isChildWriteLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents a write lock.
- isClientCellBlockSupport() - 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.
- isClientCellBlockSupport() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosing() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isClusterShutdown() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Checks if cluster is up.
- isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
- isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- isCompleted(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- isCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Check if the entire procedure has globally completed, or has been aborted.
- isCompletelyFree() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isDelayed() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- isDeleted(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Check if the specified cell buffer has been deleted by a previously
seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.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.ExplicitColumnTracker
-
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isDone() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether the map is currently empty.
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- isEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
If throttling is enabled
- isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isError - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.exists().
- isFailoverCleanupDone() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by ServerShutdownHandler to make sure AssignmentManager has completed
the failover cleanup before re-assigning regions of dead servers.
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
Should the master delete the file or keep it?
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- 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.
- 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.
- isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- isFull() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isGet - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isHFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- 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.
- 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.
- isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHttpEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isHttpsEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isInitializationStartsMetaRegionAssignment() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master has started initialization and is about to do meta region assignment
- 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
-
- isInitialized() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Checks if namespace auditor is initialized.
- isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Checks the user has privileges to access to instrumentation servlets.
- isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isLoadingCfsOnDemandDefault() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
-
Deprecated.
- isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- isLogReplaying() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- isLogSplitting() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isMajorCompacted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the hbase rootdir and checks all stores have only
one file in them -- that is, they've been major compacted.
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- isMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- isMasterProcedureExecutorEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Check whether the procedure executor is enabled
- isMasterProcedureExecutorEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Check whether the procedure executor is enabled
- 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.FSUtils
-
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.
- isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isMerged() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- isMetaEdit() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaEditFamily(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaEditFamily(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- isMetaFile(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- isNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- isNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Report the status of the server.
- isOnlineSchemaChangeAllowed(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Check whether online schema change is allowed from config
- isOperationRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isOperationRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active
RPC call to a database command.
- isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isParallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
A flag that enables StoreFileScanner parallel-seeking
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
check whether the peer is enabled or not
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Memory IO engine is always unable to support persistent storage for the
cache
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
File IO engine is always able to support persistent storage for the cache
- isPersistent() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified procedure is done.
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Check if the procedure is finished successfully
- isPublishStatusInZk() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isQuotaEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Returns true if the support for quota is enabled
- isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- isReadFromSystemAuthUser() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isReadOnly() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isReadOnly(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether this region replica can accept writes.
- isReady() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Check whether the log splitter is ready to supply tasks
- isReady() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isRecoveredEdits(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if the given path is the one with 'recovered.edits' dir.
- isRecovering() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isRecovering() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isReference(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isRegionInState(HRegionInfo, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInState(String, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInTransition(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionMarkedRecoveringInZK(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
check if /hbase/recovering-regions/ exists.
- isRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionOnline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionReplicaReplicationEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionReplicaStoreFileRefreshEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionReplicaWaitForPrimaryFlushEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- 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.regionserver.wal.WALEdit
-
- isReplaying() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- isReplaying() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- isReplication(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- isRescanNode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isRescanNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isReservedFileInfoKey(byte[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Return true if the given file info key is reserved for internal use.
- isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isRestoreDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Returns the status of a restore operation.
- isRestoreSnapshotDone(RpcController, MasterProtos.IsRestoreSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns the status of the requested snapshot restore/clone operation.
- isReturnValueDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isReturnValueDelayed() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- isRPCRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isRPCRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active
RPC call.
- isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- isSameHdfs(Configuration, FileSystem, FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSHDFSUtils
-
- isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- isSequenceIdFile(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Is the given file a region open sequence id file.
- isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is known to be dead.
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isServerReachable(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a region server is reachable and has the expected start code
- isServerShutdownHandlerEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
ServerShutdownHandlerEnabled is set false before completing
assignMeta to prevent processing of ServerShutdownHandler.
- isServerShutdownHandlerEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- isShowQueueDump(Configuration) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- isSingleNode() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified snapshot is done.
- isSnapshotDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check if the specified snapshot is done
- isSnapshotOwner(HBaseProtos.SnapshotDescription, User) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Check if the user is this table snapshot's owner
- isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isSplitting() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- isSplitting() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare of path component.
- isStop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
- isStop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopping() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- isTableAvailableAndInitialized() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
This method checks if the namespace table is assigned and then
tries to create its HTable.
- isTableInfoExists(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Checks if a current table info file exists for the given table
- isTablePresent(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Checks if table is present.
- isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
check if table is present.
- isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks if table is marked in specified state in ZK (using cache only).
- isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks if table is marked in specified state in ZK.
- isTaskPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isTEST_FORCE_REFRESH() - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- 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
-
- istream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Stream to read from.
- istreamNoFsChecksum - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
The file system stream of the underlying
HFile
that
does not do checksum verification in the file system
- isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isUninstantiated() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isUnpacked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return true when this block's buffer has been unpacked, false otherwise.
- isUsecache() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- isUsingL0Flush() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return if the specified file is a valid store file or not.
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
-
- isValidState(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- isVisibilityTagsPresent(Cell) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- iterator() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- 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.regionserver.CellSkipListSet
-
- iterator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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.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.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.LoadIncrementalHFiles
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
Main entry point.
- 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.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.migration.UpgradeTo96
-
- 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.HRegion
-
Facility for dumping and compacting catalog tables.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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.wal.Compressor
-
Command line tool to compress and uncompress WALs.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
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.HLogPrettyPrinter
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
Main program
- 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.tool.Canary
-
- 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
-
Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
-
Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HFileV1Detector
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JSONBean
-
- 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.MapreduceDependencyClasspathTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.Merge
-
- 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.ZKDataMigrator
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
Run the tool.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServer
-
Run the tool.
- MAJOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Major compaction flag in FileInfo
- majorRangeFromRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- majorRangeToRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- makeImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- makeKey(byte[], TableName, long, long, List<UUID>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- makeNamespaceDirs() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
Create the system and default namespaces dirs
- makeRenderer() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- makeRenderer(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- makeRenderer(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- makeRenderer(CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- makeRenderer(CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- makeRenderer(HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- makeRenderer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- makeRenderer(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- 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
-
- 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<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.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<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Pass the key, value to reduce.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
Map method that compares every scanned row with the equivalent from
a distant cluster.
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.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<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Convert a line of TSV text into an HBase table row.
- map(WALKey, WALEdit, Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- 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 for input in M/R jobs.
- 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
-
- markComplete(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- markComplete(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- markCorrupted(Path, String, FileSystem) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
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
-
- markRegionsOffline(MasterProcedureEnv, TableName, Boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark regions of the table offline with retries
- markRegionsOnline(MasterProcedureEnv, TableName, Boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark offline regions of the table online with retry
- markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Mark regions in recovering state for distributed log replay
- markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
Create znodes /hbase/recovering-regions/[region_ids...]/[failed region server names ...] for
all regions of the passed in region servers
- markRegionsRecovering(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- markTableAsDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
Tries to remove the queue and the table-lock of the specified table.
- master - Variable in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
-
- master - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- MASTER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- MASTER_HFILE_CLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- master_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- master_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.master_jsp
-
- MASTER_PROCEDURE_LOGDIR - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
-
- MASTER_PROCEDURE_THREADS - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
-
- MASTER_PROCEUDRE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- MASTER_SNAPSHOT_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- MasterCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- 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
-
- MasterDDLOperationHelper - Class in org.apache.hadoop.hbase.master.procedure
-
Helper class for schema change procedures
- MasterDumpServlet - Class in org.apache.hadoop.hbase.master
-
- MasterDumpServlet() - Constructor for class org.apache.hadoop.hbase.master.MasterDumpServlet
-
- 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, including splitting log files, checking file
system status, etc.
- MasterFileSystem(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterFileSystem
-
- MasterFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
-
- MasterFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- MasterObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines coprocessor hooks for interacting with operations on the
HMaster
process.
- MasterProcedureConstants - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureEnv - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureEnv(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- MasterProcedureEnv.MasterProcedureStoreListener - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureEnv.MasterProcedureStoreListener(HMaster) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
-
- MasterProcedureEnv.WALStoreLeaseRecovery - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureEnv.WALStoreLeaseRecovery(HMaster) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.WALStoreLeaseRecovery
-
- MasterProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
A life-cycle management interface for globally barriered procedures on master.
- MasterProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
- MasterProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
-
Provides the globally barriered procedure framework and environment for
master oriented operations.
- MasterProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- MasterProcedureQueue - Class in org.apache.hadoop.hbase.master.procedure
-
ProcedureRunnableSet for the Master Procedures.
- MasterProcedureQueue(Configuration, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- MasterProcedureUtil - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Master Quota Manager.
- MasterQuotaManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- MasterRpcServices - Class in org.apache.hadoop.hbase.master
-
Implements the master RPC services.
- MasterRpcServices(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MasterRpcServices
-
- masterServerName - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- MasterServices - Interface in org.apache.hadoop.hbase.master
-
Services Master supplies
- MasterSnapshotVerifier - Class in org.apache.hadoop.hbase.master.snapshot
-
General snapshot verification on the master.
- MasterSnapshotVerifier(MasterServices, HBaseProtos.SnapshotDescription, Path) - Constructor for class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
- MasterStatusServlet - Class in org.apache.hadoop.hbase.master
-
The servlet responsible for rendering the index page of the
master.
- MasterStatusServlet() - Constructor for class org.apache.hadoop.hbase.master.MasterStatusServlet
-
- MasterStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- MasterStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- MasterStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- MasterStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
-
- MasterStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- MasterStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
-
- MasterStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- MasterStatusTmplImpl(TemplateManager, MasterStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.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)
- matcher - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- matchPermission(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Returns true if the given user has a
TablePermission
matching up
to the column family portion of a permission.
- matchPermission(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System uses this for deciding whether a Cell can be deleted by matching visibility expression
in Delete mutation and the cell in consideration.
- 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_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_FILES_PER_REGION_PER_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- 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_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum supported HFile format version
- MAX_MEMSTORE_TS_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Max memstore (mvcc) timestamp in FileInfo
- MAX_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
- 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_RUNNING_TIME_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- MAX_SEQ_ID_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
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_STEPS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- MAX_TAGS_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum length of key in HFile.
- maxKeyCount - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Maximum key count after compaction (for blooms)
- maxKeys - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Max Keys expected for the bloom
- maxMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- maxMVCCReadpoint - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Latest memstore read point found in any of the involved files
- maxReadPointToTrackVersions - Variable in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
readPoint over which the KVs are unconditionally included
- maxRowSize - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- maxSeqId - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
The last key in the files we're compacting.
- maxTagsLength - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Max tags length
- mBeanServer - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
MBean server.
- md - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- member - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- 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_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- 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
-
- MemoryBoundedLogMessageBuffer - Class in org.apache.hadoop.hbase.monitoring
-
A size-bounded repository of alerts, which are kept
in a linked list.
- MemoryBoundedLogMessageBuffer(long) - Constructor for class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
- memstore - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- MemStore - Interface in org.apache.hadoop.hbase.regionserver
-
The MemStore holds in-memory modifications to the Store.
- 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_PERIODIC_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key for the periodic flush interval
- 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
-
- MemStoreChunkPool - Class in org.apache.hadoop.hbase.regionserver
-
- MemStoreLAB - Interface in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- memstoreReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MemStoreSnapshot - Class in org.apache.hadoop.hbase.regionserver
-
Holds details of the snapshot taken on a MemStore.
- MemStoreSnapshot(long, int, long, TimeRangeTracker, KeyValueScanner) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- merge(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Merge two regions whether they are adjacent or not.
- Merge - Class in org.apache.hadoop.hbase.util
-
Utility that can merge any two regions in the same table: adjacent,
overlapping or disjoint.
- Merge() - Constructor for class org.apache.hadoop.hbase.util.Merge
-
default constructor
- Merge(Configuration) - Constructor for class org.apache.hadoop.hbase.util.Merge
-
- MERGE_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- MERGE_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- MERGE_TRANSACTION_IMPL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- mergeAdjacent(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Merge two HRegions.
- mergeRegionDirs(Path, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Merge hdfs data by moving from contained HbckInfo into targetRegionDir.
- mergeRegions(RpcController, AdminProtos.MergeRegionsRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Merge regions on the region server.
- 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
-
- meta - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- META_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.master.RegionStateStore
-
The delimiter for meta columns for replicaIds > 0
- META_WAL_PROVIDER_ID - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
The hbase:meta region's WAL filename extension
- metaBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Meta block index reader -- always single level
- metaData - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Writable
s representing meta block data.
- metadata - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- METAFAMILY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- metaLocation - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- MetaMigrationConvertingToPB - Class in org.apache.hadoop.hbase
-
Deprecated.
will be removed for the major release after 0.96.
- MetaMigrationConvertingToPB() - Constructor for class org.apache.hadoop.hbase.MetaMigrationConvertingToPB
-
Deprecated.
- metaNames - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Meta block names.
- metaRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if meta region exists
- MetaServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
-
Shutdown handler for the server hosting hbase:meta
- MetaServerShutdownHandler(Server, MasterServices, DeadServer, ServerName) - Constructor for class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
-
- metaTableLocator - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MetaUtils - Class in org.apache.hadoop.hbase.util
-
Contains utility methods for manipulating HBase meta tables.
- MetaUtils() - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
-
Default constructor
- MetaUtils(Configuration) - Constructor for class org.apache.hadoop.hbase.util.MetaUtils
-
- metrics - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MetricsAssignmentManager - Class in org.apache.hadoop.hbase.master
-
- MetricsAssignmentManager() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- metricsBalancer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- MetricsBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
Faced for exposing metrics about the balancer.
- MetricsBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- MetricsHBaseServer - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServer(String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- MetricsHBaseServerWrapperImpl - Class in org.apache.hadoop.hbase.ipc
-
- 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
-
- MetricsMasterFileSystem - Class in org.apache.hadoop.hbase.master
-
- MetricsMasterFileSystem() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
- 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
-
- 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) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- MetricsRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
This class is for maintaining the various regionserver statistics
and publishing them through the metrics interfaces.
- MetricsRegionServer(MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- MetricsRegionWrapperImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionWrapperImpl(HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
-
- MetricsSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics for a sink and publishing them
through the metrics interfaces.
- MetricsSink() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- MetricsSnapshot - Class in org.apache.hadoop.hbase.master
-
- MetricsSnapshot() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshot
-
- metricsSnapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- MetricsSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
- MetricsSource(String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Constructor used to register the metrics
- 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
-
- MetricsWALEditsReplay - Class in org.apache.hadoop.hbase.regionserver.wal
-
Class used to push numbers about WAL edits replay into the metrics subsystem.
- MetricsWALEditsReplay() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALEditsReplay
-
- 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.HFileBlockIndex.BlockIndexReader
-
An approximation to the
HFile
's mid-key.
- midkey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- midkey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- migrateACL() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- migrateDotDirs() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
Rename all the dot dirs -- .data, .archive, etc.
- migrateFSTableDescriptorsIfNecessary(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptorMigrationToSubdir
-
Deprecated.
- migrateMeta() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- migrateSnapshots() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- migrateTables() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
Migrate all tables into respective namespaces, either default or system.
- 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_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_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.Leases
-
- 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) - Constructor for class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- 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_VERSION_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
In HFile V2 minor version that does not support checksums
- MINOR_VERSION_WITH_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Minor versions in HFile V2 starting with this number have hbase checksums
- minSeqIdToKeep - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Min SeqId to keep during a major compaction
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- miss(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- modifyColumn(TableName, HColumnDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Modify Column of a table
- modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyColumn(TableName, HColumnDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the column descriptor of an existing column in an existing table
- ModifyColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to modify a column family from an existing table.
- ModifyColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- ModifyColumnFamilyProcedure(MasterProcedureEnv, TableName, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify an existing namespace
- ModifyRegionUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the regions.
- ModifyRegionUtils.RegionEditTask - Interface in org.apache.hadoop.hbase.util
-
- ModifyRegionUtils.RegionFillTask - Interface in org.apache.hadoop.hbase.util
-
- modifyTable(TableName, HTableDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyTable(TableName, HTableDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the descriptor of an existing table
- ModifyTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
- ModifyTableHandler(TableName, HTableDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- ModifyTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- ModifyTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- ModifyTableProcedure(MasterProcedureEnv, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- monitor - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- monitor - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
monitor to check for errors
- MonitoredRPCHandler - Interface in org.apache.hadoop.hbase.monitoring
-
A MonitoredTask implementation optimized for use with RPC Handlers
handling frequent, short duration tasks.
- MonitoredRPCHandlerImpl - Class in org.apache.hadoop.hbase.monitoring
-
A MonitoredTask implementation designed for use with RPC Handlers
handling frequent, short duration tasks.
- MonitoredRPCHandlerImpl() - Constructor for class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- MonitoredTask - Interface in org.apache.hadoop.hbase.monitoring
-
- MonitoredTask.State - Enum in org.apache.hadoop.hbase.monitoring
-
- moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- moveAsideBadEditsFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Move aside a bad edits file.
- movedRegionCleanerPeriod() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- movedRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- moveTableToTemp(TableName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Move the specified table to the hbase temp directory
- msgInterval - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
- MultiHConnection - Class in org.apache.hadoop.hbase.util
-
Provides ability to create multiple HConnection instances and allows to process a batch of
actions using HConnection.processBatchCallback()
- MultiHConnection(Configuration, int) - Constructor for class org.apache.hadoop.hbase.util.MultiHConnection
-
Create multiple HConnection instances and initialize a thread pool executor
- MultiRowMutationEndpoint - Class in org.apache.hadoop.hbase.coprocessor
-
- MultiRowMutationEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- 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
-
- MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
- MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- 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
-
- MultiTableOutputFormat.MultiTableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
Record writer for outputting to multiple HTables.
- MultiTableOutputFormat.MultiTableRecordWriter(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- 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
-
- MultiVersionConsistencyControl - Class in org.apache.hadoop.hbase.regionserver
-
Manages the read/write consistency within memstore.
- MultiVersionConsistencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Default constructor.
- MultiVersionConsistencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
-
- 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.
- mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Mutate data in a table.
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- 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.
- mutateRows(RpcController, MultiRowMutationProtos.MutateRowsRequest, RpcCallback<MultiRowMutationProtos.MutateRowsResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform atomic mutations within the region w/o nonces.
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform atomic 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.
- mutation - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
-
- MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
- MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- ParallelSeekHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handler to seek storefiles in parallel.
- ParallelSeekHandler(KeyValueScanner, Cell, long, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- param - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- parentLockNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- parse(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- parse(String) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- parse(Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperMainServer
-
- ParseException - Exception in org.apache.hadoop.hbase.security.visibility
-
- ParseException() - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.SplitLogTask
-
- parseFromProtoRequest(AdminProtos.CloseRegionRequest) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Construct CloseRegionDetails instance from CloseRegionRequest.
- parseFromProtoRequest(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Construct OpenRegionDetails instance from part of protobuf request.
- parseFromProtoRequest(AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
Parse ZK-related fields from request.
- parseFromProtoRequest(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
Parse ZK-related fields from request.
- parseLastFlushedSequenceIdFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- 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.
- passesDeleteFamilyBloomFilter(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- passesGeneralBloomFilter(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
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.StoreFile.Reader
-
Checks whether the given scan rowkey range overlaps with the current storefile's
- path - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Path of file
- path - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
May be null if we were passed a stream.
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- path - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
-
- path - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
-
- pathPrefix - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- pause(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- PB_WAL_COMPLETE_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- PB_WAL_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- PBUF_TRAILER_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
HFile minor version that introduced pbuf filetrailer
- peek() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- 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.StoreFileScanner
-
- peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- peek() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- peek() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- peerListChanged(List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- peerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- PER_BLOCK_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- performCompaction(InternalScanner, Compactor.CellSink, long, boolean, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Performs the compaction.
- PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- placeSecondaryAndTertiaryWithRestrictions(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
- poll() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- poll() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
- poll() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- poll() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- poll() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- pollFirst() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
- pollLast() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- 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.
- populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Unassign all regions, so that they go through the regular region
assignment flow (in assignment manager) and are re-opened.
- populatePool(ExecutorService) - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- 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.RpcServer
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a abortProcedure request has been processed.
- postAbortProcedure() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the new column family has been created.
- postAddColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the new column family has been created.
- postAddColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after Append
- postAppend(Append, Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- postAppend(long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- postAppend(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post append to the writer.
- postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region assignment has been requested.
- postAssign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postBalance(ObserverContext<MasterCoprocessorEnvironment>, List<RegionPlan>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the balancing plan has been submitted.
- postBalance(List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the flag to enable/disable balancing has changed.
- postBalanceSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postBatchMutate(ObserverContext<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(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- postBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postBatchMutate(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
The hook to be executed after the process() and applying the Mutations to region.
- postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the completion of batch put/delete and will be called even if the batch operation
fails
- postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after bulkLoadHFile.
- postBulkLoadHFile(List<Pair<byte[], String>>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after checkAndDelete
- postCheckAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after checkAndPut
- postCheckAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot clone operation has been requested.
- postCloneSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as closed to the master.
- postClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region is closed
- postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCloseRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, 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(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCompact(Store, StoreFile, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the store compaction has completed.
- postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>, 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(ObserverContext<RegionCoprocessorEnvironment>, Store, ImmutableList<StoreFile>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCompactSelection(Store, ImmutableList<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the
StoreFile
s to be compacted have been selected from the available
candidates.
- postCompleteSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postCompleteSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after any split request is processed.
- postCompleteSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a split is completed irrespective of a failure or success.
- postCreateCoprocScanner(CompactionRequest, ScanType, InternalScanner, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Calls coprocessor, if any, to create scanners - after normal scanner creation.
- postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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 class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- 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
-
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postCreateTable(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postCreateTableHandler(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client deletes a value.
- postDelete(Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the column family has been deleted.
- postDeleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the column family has been deleted.
- postDeleteColumnHandler(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteNamespace operation has been requested.
- postDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the delete snapshot operation has been requested.
- postDeleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteTable operation has been requested.
- postDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
deletes a
table.
- postDeleteTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Action after disabling table.
- postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the disableTable operation has been requested.
- postDisableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the enableTable operation has been requested.
- postEnableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postEndpointInvocation(ObserverContext<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
-
- postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client tests for existence using a Get.
- postExists(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a Store's memstore is flushed to disk.
- postFlush() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a memstore flush
- postFlush(Store, StoreFile) - 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
-
- postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a client makes a GetClosestRowBefore request.
- postGetClosestRowBefore(byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client performs a Get
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Deprecated.
Use postGetTableDescriptors with regex instead.
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableDescriptors request has been processed.
- postGetTableDescriptors(List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Deprecated.
- postGetTableDescriptors(List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableNames request has been processed.
- postGetTableNames(List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after increment
- postIncrement(Increment, Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean, long) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.
This hook is no longer called by the RegionServer
- postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the ScanQueryMatcher creates ScanDeleteTracker.
- postInstantiateDeleteTracker(DeleteTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listNamespaceDescriptors request has been processed.
- postListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listProcedures request has been processed.
- postListProcedures(List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListProcedures(ObserverContext<MasterCoprocessorEnvironment>, List<ProcedureInfo>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after listSnapshots request has been processed.
- postListSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- postLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL has been archived.
- postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the log replay on the region is over.
- postLogReplay() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after log replay on region
- postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postLogReplay(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- 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.replication.regionserver.Replication
-
- postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
called after the regions merge.
- postMerge(HRegion, HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after PONR step as part of regions merge transaction.
- postMergeCommit(HRegion, HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the column family has been updated.
- postModifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the column family has been updated.
- postModifyColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyNamespace operation has been requested.
- postModifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyTable operation has been requested.
- postModifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after to modifying a table's properties.
- postModifyTableHandler(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region move has been requested.
- postMove(HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a new cell has been created during an increment operation, but before
it is committed to the WAL or memstore.
- postMutationBeforeWAL(RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as open to the master.
- postOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region open
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Region related hooks
- postOpenDeployTasks(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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
- postOpenDeployTasks(Region) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- postProcess(HRegion, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- postProcess(HRegion, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
The hook to be executed after process() and applying the Mutations to region.
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client stores a value.
- postPut(Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region has been marked offline.
- postRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after executing replication request to shipping log entries.
- postReplicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot restore operation has been requested.
- postRestoreSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after the roll back of the regions merge.
- postRollBackMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called after the roll back of the split region is completed
- postRollBackSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked just after the rollback of a failed split is done
- postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- 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.
- postRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postScannerClose(ObserverContext<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
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], int, short, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, byte[], int, short, 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, byte[], int, short) - 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<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postScannerNext(ObserverContext<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(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client opens a new scanner.
- postScannerOpen(Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the namespace is stored.
- postSetNamespaceQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the table is stored.
- postSetTableQuota(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified table is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified namespace is stored.
- postSetUserQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the snapshot operation has been requested.
- postSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSplit(ObserverContext<RegionCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postSplit(ObserverContext<RegionCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.
Use postCompleteSplit() instead
- postSplit(Region, Region) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked just after a split
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately after an active master instance has completed
initialization.
- postStartMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Master related hooks
- postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postStartRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the creation of Reader for a store file.
- postStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postSync() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
-
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- postSync(long, int) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post writer sync.
- postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
truncates a
table.
- postTruncateTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region unassignment has been requested.
- postUnassign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
Implementers should override this version of the method and leave the deprecated one as-is.
- postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a
WALEdit
replayed for this region.
- postWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postWALRestore(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
Implementers should override this method and leave the deprecated version as-is.
- postWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called after a
WALEdit
is writen to WAL.
- postWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
- postWALWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, 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
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- pread - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to adding a new column family to the table.
- preAddColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preAddColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to adding a new column family to the table.
- preAddColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Append.
- preAppend(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Append but after acquiring rowlock.
- preAppendAfterRowLock(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to assigning a specific region.
- preAssign(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>) - 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.
- preBalance() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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.
- preBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preBatchMutate(ObserverContext<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(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- preBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preBatchMutate(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
The hook to be executed after the process() but before applying the Mutations to region.
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before bulkLoadHFile.
- preBulkLoadHFile(List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Verifies user has CREATE privileges on
the Column Families involved in the bulkLoadHFile
request.
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndDelete.
- preCheckAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndDelete but after acquiring rowock.
- preCheckAndDeleteAfterRowLock(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndPut.
- preCheckAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndPut but after acquiring rowlock.
- preCheckAndPutAfterRowLock(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call.
- preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Authorization security check for
SecureBulkLoadProtocol.cleanupBulkLoad()
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is cloned.
- preCloneSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as closed to the master.
- preClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region is closed
- preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to writing the
StoreFile
s selected for compaction into a new
StoreFile
.
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCompact(Store, InternalScanner, ScanType, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to rewriting the store files selected for compaction
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to writing the
StoreFile
s selected for compaction into a new
StoreFile
and prior to creating the scanner used to read the input files.
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCompactScannerOpen(Store, List<StoreFileScanner>, ScanType, long, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to selecting the
StoreFiles
to compact from the list of
available candidates.
- preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<StoreFile>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCompactSelection(Store, List<StoreFile>, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to selecting the
StoreFile
s for compaction from the list of currently
available candidates.
- preCreateCoprocScanner(CompactionRequest, ScanType, long, List<StoreFileScanner>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Calls coprocessor, if any, to create compaction scanner - before normal scanner creation.
- preCreateCoprocScanner(CompactionRequest, ScanType, long, List<StoreFileScanner>, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
.
- preCreateTable(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, HTableDescriptor, HRegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
.
- preCreateTableHandler(HTableDescriptor, HRegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client deletes a value.
- preDelete(Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to deleting the entire column family.
- preDeleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to deleting the entire column family.
- preDeleteColumnHandler(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a
namespace
It can't bypass the default action, e.g., ctx.bypass() won't have effect.
- preDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is deleted.
- preDeleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a
table.
- preDeleteTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Action before disabling table.
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to disabling a table.
- preDisableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to enabling a table.
- preEnableTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preEndpointInvocation(ObserverContext<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
-
- preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client tests for existence using a Get.
- preExists(Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- 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.
- PrefetchExecutor - Class in org.apache.hadoop.hbase.io.hfile
-
- PrefetchExecutor() - Constructor for class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- PREFIX_LENGTH_KEY_DEPRECATED - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a Store's memstore is flushed to disk.
- preFlush(Store, InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush
- preFlush() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush
- preFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a memstore is flushed to disk and prior to creating the scanner to read from
the memstore.
- preFlushScannerOpen(Store, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a client makes a GetClosestRowBefore request.
- preGetClosestRowBefore(byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], Result) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getNamespaceDescriptor request has been processed.
- preGetNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client performs a Get
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Deprecated.
Use preGetTableDescriptors with regex instead.
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableDescriptors request has been processed.
- preGetTableDescriptors(List<TableName>, List<HTableDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Deprecated.
- preGetTableDescriptors(List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<HTableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableNames request has been processed.
- preGetTableNames(List<HTableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Increment.
- preIncrement(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Increment but after acquiring rowlock.
- preIncrementAfterRowLock(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.
This hook is no longer called by the RegionServer
- preIncrementColumnValue(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listNamespaceDescriptors request has been processed.
- preListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listProcedures request has been processed.
- preListProcedures() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before listSnapshots request has been processed.
- preListSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preLogArchive(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- 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 class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- 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.replication.regionserver.Replication
-
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Call before the master initialization is set to true.
- preMasterInitialization() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before the regions merge.
- preMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before PONR step as part of regions merge transaction.
- preMergeCommit(HRegion, HRegion, List<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region, List<Mutation>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a column family's attributes.
- preModifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyColumn(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a column family's attributes.
- preModifyColumnHandler(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a namespace's properties.
- preModifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTableHandler(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to moving a given region from one region server to another.
- preMove(HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as open to the master.
- preOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region open.
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- prepare(E) - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
- prepare() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event handlers should do all the necessary checks in this method (rather than
in the constructor, or in process()) so that the caller, which is mostly executed
in the ipc context can fail fast.
- prepare() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- prepare(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Check merge inputs and prepare the transaction.
- prepare(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Does checks on merge inputs.
- prepare() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Check split inputs and prepare the transaction.
- prepare() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
Does checks on split inputs.
- prepareBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.Region.BulkLoadListener
-
Called before an HFile is actually loaded
- prepareBulkLoad(RpcController, SecureBulkLoadProtos.PrepareBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.PrepareBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- prepareDelete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- prepareDelete(Delete) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Prepare a delete for a row mutation processor
- prepareDeleteTimestamps(Mutation, Map<byte[], List<Cell>>, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- prepareDeleteTimestamps(Mutation, Map<byte[], List<Cell>>, byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Set up correct timestamps in the KVs in Delete object.
- prepareForBlockReader(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Prepares the streams for block reader.
- prepareLogReplay(ServerName, Set<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Mark regions in recovering state when distributedLogReplay are set true
- prepareMutationsForMerge(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, List<Mutation>, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- prepareTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Prepare the new task
- prepareTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- prepareToSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Give the region a chance to prepare before it is split.
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Called from prepare() while holding the table lock.
- prepareWithTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call.
- prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>, SecureBulkLoadProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Authorization check for
SecureBulkLoadProtocol.prepareBulkLoad()
- prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the server updates the timestamp for version delete with latest timestamp.
- prePrepareTimeStampForDeleteVersion(Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preProcess(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- preProcess(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
The hook to be executed before process().
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client stores a value.
- prePut(Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to marking a given region as offline.
- preRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before executing replication request to shipping log entries.
- preReplicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>, List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is restored.
- preRestoreSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before the roll back of the regions merge.
- preRollBackMerge(HRegion, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment>, Region, Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preRollBackSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called before the roll back of the split region is completed
- preRollBackSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked just before the rollback of a failed split is started
- preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- 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.
- preRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preScannerClose(ObserverContext<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
-
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preScannerNext(ObserverContext<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
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client opens a new scanner.
- preScannerOpen(Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preSelect(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Called before coprocessor preCompactSelection and should filter the candidates
for coprocessor; i.e.
- preSelectCompactionForCoprocessor(Collection<StoreFile>, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- preSelectFilesForCoprocessor(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the namespace is stored.
- preSetNamespaceQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the table is stored.
- preSetTableQuota(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified table is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified namespace is stored.
- preSetUserQuota(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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.
- preShutdown() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new snapshot is taken.
- preSnapshot(HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, HBaseProtos.SnapshotDescription, HTableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Deprecated.
Use preSplit(
final ObserverContext c, byte[] splitRow)
- preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is split.
- preSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked just before a split
- preSplit(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked just before a split
- preSplit(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSplit(ObserverContext<RegionCoprocessorEnvironment>, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSplitAfterPONR(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preSplitAfterPONR(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called after PONR step as part of split transaction
Calling
ObserverContext.bypass()
has no
effect in this hook.
- preSplitAfterPONR() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preSplitBeforePONR(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called before PONR step as part of split transaction.
- preSplitBeforePONR(byte[], List<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- PressureAwareCompactionThroughputController - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- PressureAwareCompactionThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- preStop(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately prior to stopping this
HMaster
process.
- preStopMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before stopping region server.
- preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFile.Reader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before creation of Reader for a store file.
- preStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, Scan, NavigableSet<byte[]>, KeyValueScanner) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, Scan, NavigableSet<byte[]>, KeyValueScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a store opens a new scanner.
- preStoreScannerOpen(Store, Scan, NavigableSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- 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
-
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
truncates a
table.
- preTruncateTableHandler(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to unassigning a given region.
- preUnassign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- prevPtr - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The previous entry in the LRU list (towards LRU)
- preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
Implementers should override this version of the method and leave the deprecated one as-is.
- preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a
WALEdit
replayed for this region.
- preWALRestore(ObserverContext<RegionCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preWALRestore(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preWALRestore(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
Implementers should override this method and leave the deprecated version as-is.
- preWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called before a
WALEdit
is writen to WAL.
- preWALWrite(ObserverContext<WALCoprocessorEnvironment>, HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
- preWALWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- print(boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- print(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- printAssignmentPlan(FavoredNodesPlan) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Print the assignment plan to the system output stream
- printDispersionScores(TableName, SnapshotOfRegionAssignmentFromMeta, int, FavoredNodesPlan, boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- printLocalityAndDispersionForCurrentPlan(Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- printUsageAndExit() - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
-
- priority - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Chaining priority
- PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
-
- PriorityFunction - Interface in org.apache.hadoop.hbase.ipc
-
Function to figure priority of incoming request.
- Procedure - Class in org.apache.hadoop.hbase.procedure
-
A globally-barriered distributed procedure.
- Procedure(ProcedureCoordinator, ForeignExceptionDispatcher, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
-
Creates a procedure.
- Procedure(ProcedureCoordinator, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
-
Create a procedure.
- ProcedureCoordinator - Class in org.apache.hadoop.hbase.procedure
-
This is the master side of a distributed complex procedure execution.
- ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Create and start a ProcedureCoordinator.
- ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Create and start a ProcedureCoordinator.
- ProcedureCoordinatorRpcs - Interface in org.apache.hadoop.hbase.procedure
-
RPCs for the coordinator to run a barriered procedure with subprocedures executed at
distributed members.
- ProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
- ProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManager
-
- ProcedureManagerHost<E extends ProcedureManager> - Class in org.apache.hadoop.hbase.procedure
-
Provides the common setup framework and runtime services for globally
barriered procedure invocation from HBase services.
- ProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- ProcedureMember - Class in org.apache.hadoop.hbase.procedure
-
Process to kick off and manage a running
Subprocedure
on a member.
- ProcedureMember(ProcedureMemberRpcs, ThreadPoolExecutor, SubprocedureFactory) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Instantiate a new ProcedureMember.
- ProcedureMemberRpcs - Interface in org.apache.hadoop.hbase.procedure
-
This is the notification interface for Procedures that encapsulates message passing from
members to a coordinator.
- ProcedurePrepareLatch - Class in org.apache.hadoop.hbase.master.procedure
-
Latch used by the Master to have the prepare() sync behaviour for old
clients, that can only get exceptions in a synchronous way.
- ProcedurePrepareLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- ProcedurePrepareLatch.CompatibilityLatch - Class in org.apache.hadoop.hbase.master.procedure
-
- ProcedurePrepareLatch.CompatibilityLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- procedures - Variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- ProcedureSyncWait - Class in org.apache.hadoop.hbase.master.procedure
-
Helper to synchronously wait on conditions.
- ProcedureSyncWait.Predicate<T> - Interface in org.apache.hadoop.hbase.master.procedure
-
- process(RpcController, RowProcessorProtos.ProcessRequest, RpcCallback<RowProcessorProtos.ProcessResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
Pass a processor to region to process multiple rows atomically.
- process() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
This method is the main processing loop to be implemented by the various
subclasses.
- process() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.DispatchMergingRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- process() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Execute the core common portions of taking a snapshot.
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
- process(long, HRegion, List<Mutation>, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
HRegion handles the locks and MVCC and invokes this method properly.
- processBatchCallback(List<? extends Row>, TableName, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
Randomly pick a connection and process the batch of actions for a given table
- processDeadRegion(HRegionInfo, AssignmentManager) - Static method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
Process a dead region from a dead RS.
- processDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- processDeadServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- processEndOfFile() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
If the queue isn't empty, switch to the next one
Else if this is a recovered queue, it means we're done!
Else we'll just continue to try reading the log file
- 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
- processKV(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, Put, Delete) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- processRegionMergeRequest(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
- processRegionMergeRequest(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- processRequest(byte[]) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- 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
-
- 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.master.OfflineCallback
-
- processRowsWithLocks(RowProcessor<?, ?>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Performs atomic multiple reads and writes on a given row.
- processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Performs atomic multiple reads and writes on a given row.
- processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Performs atomic multiple reads and writes on a given row.
- processServerShutdown(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Process shutdown server removing any assignments.
- processTransition(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, SplitTransactionCoordination.SplitTransactionDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
Required by AssignmentManager
- processTransition(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, SplitTransactionCoordination.SplitTransactionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
- progress - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- progress() - Method in interface org.apache.hadoop.hbase.util.CancelableProgressable
-
Report progress.
- progress() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- PropagatingConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
-
This extension to ConfigurationObserver allows the configuration to propagate to the children of
the current
ConfigurationObserver
.
- ProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
A Protobuf based WAL has the following structure:
- ProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- 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
-
- ProtoUtil - Class in org.apache.hadoop.hbase.util
-
- ProtoUtil() - Constructor for class org.apache.hadoop.hbase.util.ProtoUtil
-
- publish(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- publish(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- publishReadFailure(String, String) - Method in interface org.apache.hadoop.hbase.tool.Canary.ExtendedSink
-
- publishReadFailure(String, String) - Method in class org.apache.hadoop.hbase.tool.Canary.RegionServerStdOutSink
-
- publishReadFailure(HRegionInfo, Exception) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
-
- publishReadFailure(HRegionInfo, HColumnDescriptor, Exception) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
-
- publishReadFailure(HRegionInfo, Exception) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- publishReadFailure(HRegionInfo, HColumnDescriptor, Exception) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- publishReadTiming(String, String, long) - Method in interface org.apache.hadoop.hbase.tool.Canary.ExtendedSink
-
- publishReadTiming(String, String, long) - Method in class org.apache.hadoop.hbase.tool.Canary.RegionServerStdOutSink
-
- publishReadTiming(HRegionInfo, HColumnDescriptor, long) - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
-
- publishReadTiming(HRegionInfo, HColumnDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- purgeTimeout - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- put(Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- put(K, V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Insert a key-value mapping into the map.
- put(Put) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Puts some data in the table.
- put(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- putAll(Map<? extends byte[], ? extends byte[]>) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
-
Combine Puts.
- PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Puts.
- PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- 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
-
- randomAssignment(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Used to assign a single region to a random server.
- randomAssignment(HRegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- randomAssignment(HRegionInfo, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Get a random region server from the list
- RateLimiter - Class in org.apache.hadoop.hbase.quotas
-
Simple rate limiter.
- RateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.RateLimiter
-
- RatioBasedCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
The default algorithm for selecting files for compaction.
- RatioBasedCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- REACHED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- reachedZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- read(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Transfers data from the buffer array to the given byte buffer
- read(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Transfers data from file to the given byte buffer
- read(ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Transfers data from IOEngine to the given byte buffer
- read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
-
Read a Reference from FileSystem.
- READ_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
ZNode prefix used by processes acquiring reader locks
- readAllEntriesToReplicateOrNextFile(boolean, List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Read all the entries from the current log files and retain those
that need to be replicated.
- readAndProcess() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
Read off the wire.
- 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.HFileReaderV2
-
- readBlockData(long, long, int, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Reads the block at the given offset in the file with the given on-disk
size and uncompressed size.
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- reader - Variable in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- ReaderBase - Class in org.apache.hadoop.hbase.regionserver.wal
-
- ReaderBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Default constructor.
- 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.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.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- readFieldsFromPb(WALProtos.WALKey, WALCellCodec.ByteStringUncompressor) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- readFromCells(Codec.Decoder, int) - Method in class org.apache.hadoop.hbase.regionserver.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.
- readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- readLabelsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Reads back from the zookeeper.
- readLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
-
Obtain a read lock containing given metadata.
- readLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- readLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Returns a TableLock for locking the table for shared access among read-lock holders
- readLock(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
-
Obtain a read lock containing given metadata.
- readMultiLevelIndexRoot(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read the root-level metadata of a multi-level block index.
- readMvccVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Read mvcc.
- readMvccVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- readMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
read the content of znode file, expects a single line.
- readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Read next entry.
- readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
fill in the passed entry with teh next key/value.
- readNextAndSetPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Get the next entry, returned and also added in the array
- readNextDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
Scans blocks in the "scanned" section of the
HFile
until the next
data block is found.
- readOlderScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- readOnly() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Is this operation read only? If this is true, process() should not add
any mutations or it throws IOException.
- readPermissions(byte[], Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Reads a set of permissions as Writable
instances
from the input stream.
- readRawVarint32(DataInput) - Static method in class org.apache.hadoop.hbase.util.ProtoUtil
-
Read a variable length integer in the same format that ProtoBufs encodes.
- readRootIndex(DataInput, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readRootIndex(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readSnapshotInfo(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- readUserAuthsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Reads back User auth data written to zookeeper.
- readWithExtra(InputStream, byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Read from an input stream.
- readZKNodes(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
- 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.StoreFileScanner
-
- reapAllExpiredLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- reapAllExpiredLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Force releases all table locks(read and write) that have been held longer than
"hbase.table.lock.expire.ms".
- reapAllLocks() - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
If supported, attempts to reap all the locks of this type by forcefully
deleting the locks (both held and attempted).
- reapAllLocks() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- reapExpiredLocks(long) - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
If supported, attempts to reap all the locks of this type by forcefully
deleting the locks (both held and attempted) that have expired according
to the given timeout.
- reapExpiredLocks(long) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Will delete all lock znodes of this type (either read or write) which are "expired"
according to timeout.
- reapWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- reapWriteLocks() - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Force releases table write locks and lock attempts even if this thread does
not own the lock.
- rebuildMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Rebuilds meta from information in hdfs/fs.
- 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.
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
A callback that handles incoming ForeignExceptions.
- receiveAbortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Send abort to the specified procedure
- receivedReachedGlobalBarrier(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Notification that procedure coordinator has reached the global barrier
- receiveReachedGlobalBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Callback for the member rpcs to call when the global barrier has been reached.
- reconnect(KeeperException) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
A private method used to re-establish a zookeeper session with a peer cluster.
- recoveredEdits(String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.RecoveredEditsVisitor
-
- recoverFileLease(FileSystem, Path) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.WALStoreLeaseRecovery
-
- recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSHDFSUtils
-
Recover the lease from HDFS, retrying multiple times.
- recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSMapRUtils
-
- recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Method in class org.apache.hadoop.hbase.util.FSUtils
-
Recover file lease.
- recoveringRegionLock - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
In distributedLogReplay mode, we need touch both splitlog and recovering-regions znodes in one
operation.
- recoveringRegions - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Set of regions currently being in recovering state which means it can accept writes(edits from
previous failed region server) but not reads.
- RecoveringRegionWatcher - Class in org.apache.hadoop.hbase.zookeeper
-
Watcher used to be notified of the recovering region coming out of recovering state
- RecoveringRegionWatcher(ZooKeeperWatcher, HRegionServer) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoveringRegionWatcher
-
Construct a ZooKeeper event listener.
- recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- 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(Writable, Iterable<Mutation>, Reducer<Writable, Mutation, Writable, Mutation>.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
.
- reduce(ImmutableBytesWritable, Iterable<KeyValue>, Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
-
- reduce(K, Iterable<Put>, Reducer<K, Put, K, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- reduce(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- reduce(ImmutableBytesWritable, Iterable<Text>, Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- 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
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- REFRESH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- refreshAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Refreshing the age makes sure the value returned is the actual one and
not the one set a replication time
- refreshAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Convenience method to use the last given timestamp to refresh the age of the last edit.
- refreshAndGetReplicationLoad() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Refresh and Get ReplicationLoad
- refreshAndGetReplicationLoad() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- refreshAuthManager(PolicyProvider) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- refreshAuthManager(PolicyProvider) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Refresh authentication manager policy.
- refreshLabelsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- refreshNamespaceCacheFromWritable(String, byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
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(Collection<String>) - 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(Collection<String>) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Replaces the store files that the store has with the given files.
- refreshTableCacheFromWritable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- refreshUserAuthsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- region - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
-
- region - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
The region configured for this flush policy.
- Region - Interface in org.apache.hadoop.hbase.regionserver
-
Regions store data for a certain region of a table.
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
The region configured for this split policy.
- region(String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.RegionVisitor
-
- Region.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
- Region.FlushResult - Interface in org.apache.hadoop.hbase.regionserver
-
- Region.FlushResult.Result - Enum in org.apache.hadoop.hbase.regionserver
-
- Region.Operation - Enum in org.apache.hadoop.hbase.regionserver
-
- Region.RowLock - Interface in org.apache.hadoop.hbase.regionserver
-
Row lock held by a given thread.
- REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- 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_MERGES_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for merges.
- 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_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_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs class name of the peer cluster
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs impl name of the peer cluster
- REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- 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_SPLITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for splits.
- regionAssignmentWaitTimeout - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- regionClosed(HRegionInfo) - Method in interface org.apache.hadoop.hbase.master.AssignmentListener
-
The region was closed on the region server.
- RegionCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
Region
.
- RegionCoprocessorHost(Region, RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Constructor
- regionDict - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- regionFavoredNodesMap - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Map of encoded region names to the DataNode locations they should be hosted on
We store the value as InetSocketAddress since this is used only in HDFS
API (create() that takes favored nodes as hints for placing file blocks).
- regionFinder - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- RegionListTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RegionListTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- RegionListTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- RegionListTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RegionListTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- RegionListTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
-
- RegionListTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RegionListTmplImpl(TemplateManager, RegionListTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmplImpl
-
- regionMaximumEditLogSeqNum - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- regionMaxSeqIdInStores - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- RegionMergeCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordination operations for region merge transaction.
- regionMergeCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- RegionMergeCoordination.RegionMergeDetails - Interface in org.apache.hadoop.hbase.coordination
-
Dummy interface for region merge transaction details.
- RegionMergeTransaction - Interface in org.apache.hadoop.hbase.regionserver
-
Executes region merge as a "transaction".
- RegionMergeTransaction.JournalEntry - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction journal entry
- RegionMergeTransaction.RegionMergeTransactionPhase - Enum in org.apache.hadoop.hbase.regionserver
-
Each enum is a step in the merge transaction.
- RegionMergeTransaction.TransactionListener - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction listener
- RegionMergeTransactionFactory - Class in org.apache.hadoop.hbase.regionserver
-
A factory for creating RegionMergeTransactions, which execute region split as a "transaction".
- RegionMergeTransactionFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- RegionMergeTransactionImpl - Class in org.apache.hadoop.hbase.regionserver
-
- RegionMergeTransactionImpl(Region, Region, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Constructor
- RegionMergeTransactionImpl(Region, Region, boolean, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Constructor
- RegionMergeTransactionImpl.JournalEntryImpl - Class in org.apache.hadoop.hbase.regionserver
-
- RegionMergeTransactionImpl.JournalEntryImpl(RegionMergeTransaction.RegionMergeTransactionPhase) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- RegionMergeTransactionImpl.JournalEntryImpl(RegionMergeTransaction.RegionMergeTransactionPhase, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- regionName - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
-
- RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Coprocessors implement this interface to observe and mediate client actions
on the region.
- RegionObserver.MutationType - Enum in org.apache.hadoop.hbase.coprocessor
-
Mutation type for postMutationBeforeWAL hook
- regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Marks the region as offline.
- regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- regionOffline(HRegionInfo) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as offline at balancer.
- regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A region is offline, won't be in transition any more.
- regionOffline(HRegionInfo, RegionState.State) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A region is offline, won't be in transition any more.
- regionOnline(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- regionOnline(HRegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as online at balancer.
- regionOnline(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- regionOnline(HRegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A region is online, won't be in transition any more.
- regionOpened(HRegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.AssignmentListener
-
The region was opened on the specified server.
- 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
-
- 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.
- RegionPlacementMaintainer.RandomizedMatrix(int, int) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Create a randomization scheme for a matrix of a given size.
- RegionPlan - Class in org.apache.hadoop.hbase.master
-
Stores the plan for the move of an individual region.
- RegionPlan(HRegionInfo, 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.
- RegionPlan.RegionPlanComparator - Class in org.apache.hadoop.hbase.master
-
- RegionPlan.RegionPlanComparator() - Constructor for class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
-
- RegionReplicaFlushHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
HBASE-11580: With the async wal approach (HBASE-11568), the edits are not persisted to wal in
secondary region replicas.
- RegionReplicaFlushHandler(Server, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, int, HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- RegionReplicaReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
-
A
ReplicationEndpoint
endpoint which receives the WAL edits from the
WAL, and sends the edits to replicas of regions.
- RegionReplicaReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
-
RegionScanner describes iterators over rows in an HRegion.
- REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
region server process name
- REGIONSERVER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- regionserver_jsp - Class in org.apache.hadoop.hbase.generated.regionserver
-
- regionserver_jsp() - Constructor for class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
-
- 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_PROCEDURE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- 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.
- RegionServerAccounting - Class in org.apache.hadoop.hbase.regionserver
-
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
- RegionServerAccounting() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- RegionServerCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionServerCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerCoprocessorHost(RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- RegionServerFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
-
This manager class handles flushing of the regions for table on a
HRegionServer
.
- RegionServerFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder - Class in org.apache.hadoop.hbase.procedure.flush
-
- RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder
-
- RegionServerListTmpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- RegionServerListTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- RegionServerListTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- RegionServerListTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
-
- RegionServerListTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- RegionServerListTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
-
- RegionServerListTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- RegionServerListTmplImpl(TemplateManager, RegionServerListTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmplImpl
-
- RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionServerProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
A life-cycle management interface for globally barriered procedures on
region servers.
- RegionServerProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
- RegionServerProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
-
Provides the globally barriered procedure framework and environment
for region server oriented operations.
- RegionServerProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- RegionServerQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Region Server Quota Manager.
- RegionServerQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- regionServerRemoved(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
-
- RegionServerServices.PostOpenDeployContext - Class in org.apache.hadoop.hbase.regionserver
-
Context for postOpenDeployTasks().
- RegionServerServices.PostOpenDeployContext(Region, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- RegionServerServices.RegionStateTransitionContext - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerServices.RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, HRegionInfo...) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- RegionServerSnapshotManager - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
This manager class handles the work dealing with snapshots for a
HRegionServer
.
- RegionServerSnapshotManager() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- RegionServerSnapshotManager.SnapshotSubprocedureBuilder - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
Build the actual snapshot runner that will do all the 'hard' work
- RegionServerSnapshotManager.SnapshotSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
-
- regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- RegionServerTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the online region servers via ZK.
- RegionServerTracker(ZooKeeperWatcher, Server, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
- regionsInTransitionInRS - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- RegionSizeCalculator - Class in org.apache.hadoop.hbase.util
-
Computes size of each region for given table and given column families.
- RegionSizeCalculator(HTable) - Constructor for class org.apache.hadoop.hbase.util.RegionSizeCalculator
-
- RegionSizeCalculator(RegionLocator, Admin) - Constructor for class org.apache.hadoop.hbase.util.RegionSizeCalculator
-
Computes size of each region for table and given column families.
- RegionSplitCalculator<R extends 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
-
- 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
-
- 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
-
- RegionSplitter.HexStringSplit - Class in org.apache.hadoop.hbase.util
-
- RegionSplitter.HexStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- RegionSplitter.SplitAlgorithm - Interface in org.apache.hadoop.hbase.util
-
A generic interface for the RegionSplitter code to use for all it's
functionality.
- RegionSplitter.UniformSplit - Class in org.apache.hadoop.hbase.util
-
A SplitAlgorithm that divides the space of possible keys evenly.
- RegionSplitter.UniformSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- RegionStateListener - Interface in org.apache.hadoop.hbase.quotas
-
The listener interface for receiving region state events.
- RegionStates - Class in org.apache.hadoop.hbase.master
-
Region state accountant.
- RegionStateStore - Class in org.apache.hadoop.hbase.master
-
A helper to persist region state in meta.
- register(E) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- 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.CompactSplitThread
-
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.
- registerDeserializer(CacheableDeserializer<Cacheable>) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Register the given cacheable deserializer and generate an unique identifier
id for it
- registerFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Register a FlushRequestListener
- registerForWrite(RpcServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Responder
-
Add a connection to the list that want to write,
- registerListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
set the listener for task changes.
- registerListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- registerListener(EventType, EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
Subscribe to updates before and after processing instances of
EventType
.
- registerListener(AssignmentListener) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add the listener to the notification list.
- registerListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Add the listener to the notification list.
- registerObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Register an observer class
- 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.regionserver.HRegion
-
- registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- registerService(Service) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- 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
- registerTransactionListener(RegionMergeTransaction.TransactionListener) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Register a listener for transaction preparation, execution, and possibly
rollback phases.
- registerTransactionListener(RegionMergeTransaction.TransactionListener) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- registerTransactionListener(SplitTransaction.TransactionListener) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Register a listener for transaction preparation, execution, and possibly
rollback phases.
- registerTransactionListener(SplitTransaction.TransactionListener) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- registerWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Registers WALActionsListener
- release() - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
Release the lock.
- release() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Releases resources used by this writer.
- release() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
-
Release the lock already held.
- 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() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Release the lock.
- releaseBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- releaseBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Hooray!
- releaseDelegationToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Releases a previously acquired delegation token.
- releaseLatch(ProcedurePrepareLatch, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- 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.
- releaseRowLocks(List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- releaseRowLocks(List<Region.RowLock>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
If the given list of row locks is not null, releases all locks.
- releaseTableLock() - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- releaseTableLock() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- releaseTableLock() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- releaseTableRead(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
Release the read lock taken with tryAcquireTableRead()
- releaseTableWrite(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
Release the write lock taken with tryAcquireTableWrite()
- remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- remainingTasksInCoordination() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Return the number of remaining tasks
- remainingTasksInCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- remotePort - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- remove(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove all
Constraints
that have been added to the table
and turn off the constraint processing.
- remove(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove the constraint (and associated information) for the table
descriptor.
- remove(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- remove(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Deletes the mapping for the specified key if it exists.
- remove(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- remove(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Removes the table descriptor from the local cache and returns it.
- remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- remove(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- removeClosedRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
When a region is closed, it should be removed from the regionsToReopen
- removeFromNamespaceUsage(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- removeFromOnlineRegions(Region, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- removeFromOnlineRegions(Region, ServerName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
This method removes Region corresponding to hri from the Map of onlineRegions.
- removeKeyFromZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- removeListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
remove the listener for task changes.
- removeListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- removeNamespace(byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- removeNamespaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Thie method first deletes all the recovered sources for the specified
id, then deletes the normal source (deleting all related data in ZK).
- removeRecoveringRegions(Set<String>, Boolean) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
It removes recovering regions from Coordination
- removeRecoveringRegions(Set<String>, Boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
It removes recovering regions under /hbase/recovering-regions/[encoded region name] so that the
region server hosting the region can allow reads to the recovered region
- removeRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRegionFromNamespaceUsage(HRegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- removeRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRootPath(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks for the presence of the root path (using the provided conf object) in the given path.
- removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- removeStaleRecoveringRegions(Set<String>) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Removes known stale servers
- removeStaleRecoveringRegions(Set<String>) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
ZooKeeper implementation of
{@link org.apache.hadoop.hbase.master.
- removeStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Archives the specified store file from the specified family.
- removeStoreFiles(String, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Closes and archives the specified store files from the specified family.
- removeTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- removeTableData(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
Removes the table from hbase:meta and archives the HDFS files.
- removeTableFromNamespaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Remove table from namespace quota.
- renameAndSetModifyTime(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- render(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- render(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- render(Writer, CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- render(Writer, CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- render(Writer, HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- render(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- render(Writer, MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.Intf
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.Intf
-
- renderNoFlush(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.Intf
-
- renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.Intf
-
- renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.Intf
-
- renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.Intf
-
- renderNoFlush(Writer, CacheConfig, Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.Intf
-
- renderNoFlush(Writer, CacheConfig, Configuration, String, String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.Intf
-
- renderNoFlush(Writer, HRegionServer, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.Intf
-
- renderNoFlush(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.Intf
-
- renderNoFlush(Writer, MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- renewLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Renew a lease
- reOpenAllRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- reOpenAllRegions(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Reopen all regions from a table after a schema change operation.
- replaceValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Replace the value of this entry.
- replay(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replay the given changes when distributedLogReplay WAL edits from a failed RS.
- replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Call to complete a compaction.
- replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Call to complete a compaction.
- replayEntries(List<Pair<HRegionLocation, WAL.Entry>>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
-
Replay an array of actions of the same region directly into the newly assigned Region Server
- ReplayHLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
-
An HLogKey specific to WalEdits coming from replay.
- ReplayHLogKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
-
- ReplayHLogKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
-
- replayRecoveredEditsIfAny(Path, Map<byte[], Long>, CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Read the edits put under this region by wal splitting process.
- replicaRegionsNotRecordedInMeta(Set<HRegionInfo>, MasterServices) - Static method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Get a list of replica regions that are:
not recorded in meta yet.
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Do the shipping logic
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- 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.security.visibility.VisibilityReplicationEndpoint
-
- replicateEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Replicate this array of entries directly into the local cluster using the native client.
- replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
-
Carry on the list of log entries down to the sink
- replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Carry on the list of log entries down to the sink
- replicateWALEntry(AdminProtos.AdminService.BlockingInterface, WAL.Entry[]) - Static method in class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
-
A helper to replicate a list of WAL entries using admin protocol.
- replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replicate WAL entries on the region server.
- Replication - Class in org.apache.hadoop.hbase.replication.regionserver
-
Gateway to Replication.
- Replication(Server, FileSystem, Path, Path) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Instantiate the replication management (if rep is enabled).
- Replication() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Empty constructor
- ReplicationEndpoint - Interface in org.apache.hadoop.hbase.replication
-
ReplicationEndpoint is a plugin which implements replication
to other HBase clusters, or other systems.
- ReplicationEndpoint.Context - Class in org.apache.hadoop.hbase.replication
-
- ReplicationEndpoint.Context(Configuration, FileSystem, ReplicationPeerConfig, String, UUID, ReplicationPeer, MetricsSource, TableDescriptors) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- ReplicationEndpoint.ReplicateContext - Class in org.apache.hadoop.hbase.replication
-
- ReplicationEndpoint.ReplicateContext() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- ReplicationLoad - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is used for exporting some of the info from replication metrics
- ReplicationLoad() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
default constructor
- ReplicationLogCleaner - Class in org.apache.hadoop.hbase.replication.master
-
Implementation of a log cleaner that checks if a log is still scheduled for
replication before deleting it when its TTL is over.
- ReplicationLogCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- ReplicationProtbufUtil - Class in org.apache.hadoop.hbase.protobuf
-
- ReplicationProtbufUtil() - Constructor for class org.apache.hadoop.hbase.protobuf.ReplicationProtbufUtil
-
- ReplicationService - Interface in org.apache.hadoop.hbase.regionserver
-
Gateway to Cluster Replication.
- ReplicationSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible for replicating the edits coming
from another cluster.
- ReplicationSink(Configuration, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Create a sink for replication
- replicationSinkHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ReplicationSinkManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
Maintains a collection of peers to replicate to, and randomly selects a
single peer to replicate to per set of data to replicate.
- ReplicationSinkManager(HConnection, String, HBaseReplicationEndpoint, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Instantiate for a single replication peer cluster.
- ReplicationSinkManager.SinkPeer - Class in org.apache.hadoop.hbase.replication.regionserver
-
Wraps a replication region server sink to provide the ability to identify
it.
- ReplicationSinkManager.SinkPeer(ServerName, AdminProtos.AdminService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- ReplicationSinkService - Interface in org.apache.hadoop.hbase.regionserver
-
A sink for a replication stream has to expose this service.
- ReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
Class that handles the source of a replication stream.
- ReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationSource.LogsComparator - Class in org.apache.hadoop.hbase.replication.regionserver
-
Comparator used to compare logs together based on their start time
- ReplicationSource.LogsComparator() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
-
- replicationSourceHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ReplicationSourceInterface - Interface in org.apache.hadoop.hbase.replication.regionserver
-
Interface that defines a replication source
- ReplicationSourceManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible to manage all the replication
sources.
- ReplicationSourceManager(ReplicationQueues, ReplicationPeers, ReplicationTracker, Configuration, Server, FileSystem, Path, Path, UUID) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Creates a replication manager and sets the watch on all the other registered region servers
- ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
-
A source for a replication stream has to expose this service.
- ReplicationSyncUp - Class in org.apache.hadoop.hbase.replication.regionserver
-
In a scenario of Replication based Disaster/Recovery, when hbase
Master-Cluster crashes, this tool is used to sync-up the delta from Master to
Slave using the info from Zookeeper.
- ReplicationSyncUp() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- ReplicationThrottler - Class in org.apache.hadoop.hbase.replication.regionserver
-
Per-peer per-node throttling controller for replication: enabled if
bandwidth > 0, a cycle = 100ms, by throttling we guarantee data pushed
to peer within each cycle won't exceed 'bandwidth' bytes
- ReplicationThrottler(double) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
ReplicationThrottler constructor
If bandwidth less than 1, throttling is disabled
- ReplicationWALReaderManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
Wrapper class around WAL to help manage the implementation details
such as compression.
- ReplicationWALReaderManager(FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Creates the helper but doesn't open any file
Use setInitialPosition after using the constructor if some content needs to be skipped
- ReplicationZKLockCleanerChore - Class in org.apache.hadoop.hbase.master.cleaner
-
A cleaner that cleans replication locks on zk which is locked by dead region servers
- ReplicationZKLockCleanerChore(Stoppable, Abortable, int, ZooKeeperWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
-
- report(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- report(HBaseFsck.ErrorReporter) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Print a human readable summary of hfile quarantining operations.
- reportBadSink(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Report a SinkPeer
as being bad (i.e.
- reportCompactionRequestEnd(boolean, int, long) - 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.WALSplitter.OutputSink
-
- reportError(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportOperationFromWal(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Reports the operation from WAL during replay.
- reportRegionStateTransition(RpcController, RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, HRegionInfo...) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, HRegionInfo...) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, HRegionInfo...) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- reportRegionStateTransition(RegionServerStatusProtos.RegionStateTransition.TransitionCode, HRegionInfo...) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportSinkSuccess(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Report that a SinkPeer
successfully replicated a chunk of data.
- request(Path, Runnable) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- requestCompaction(Region, String) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(Region, String, List<Pair<CompactionRequest, Store>>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(Region, Store, String, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(Region, String, int, List<Pair<CompactionRequest, Store>>, User) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(Region, Store, String, int, CompactionRequest, User) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(Region, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(Region, String, List<Pair<CompactionRequest, Store>>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(Region, Store, String, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(Region, String, int, List<Pair<CompactionRequest, Store>>, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(Region, Store, String, int, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- requestCompaction(int, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- requestCompaction(int, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- requestCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- requestCompaction(int, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Deprecated.
see requestCompaction(int, CompactionRequest, User)
- requestCompaction(int, CompactionRequest, User) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- requestDelayedFlush(Region, long, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed after a delay
- requestedSize() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- requestFlush(Region, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requestLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- requestRegionsMerge(Region, Region, boolean, long, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestRollAll() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- requestSeek(Cell, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- requestSeek(Cell, 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.
- requestSplit(Region) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestSplit(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestSplit(Region, byte[], User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestSystemCompaction(Region, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestSystemCompaction(Region, Store, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requireNamespacePermission(String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Checks that the user has the given global or namespace permission.
- requireNamespacePermission(String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Checks that the user has the given global or namespace permission.
- requiresLayout() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
Move forward on the sub-lists set previously by seek.
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
This function is identical to the
KeyValueHeap.seek(Cell)
function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
- reseek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Do a reseek to the required row.
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- reseekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- reseekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- reseekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- reseekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- reseekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- reseekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- reset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Resets the Matcher
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Called between rows.
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- reset() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- reset() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Enable a basic on-heap cache for these jobs.
- resetCounters() - Static method in class org.apache.hadoop.hbase.SplitLogCounters
-
- resetErrors() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- resetKVHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- resetMembers(Procedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify Members to reset the distributed state for procedure
- resetMembers(Procedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Delete znodes that are no longer in use.
- resetScannerStack(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- resetStartTick() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Reset the cycle start tick to NOW
- ResizableBlockCache - Interface in org.apache.hadoop.hbase.io.hfile
-
BlockCache which is resizable.
- responder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- responder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- response - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
Chain of buffers to send as response.
- responseQueue - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- 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.
- restoreEdit(Store, Cell) - 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.
- restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Execute Restore/Clone snapshot operation.
- restoreSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Restore the specified snapshot
- RestoreSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Handler to Restore a snapshot.
- RestoreSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- RestoreSnapshotHelper - Class in org.apache.hadoop.hbase.snapshot
-
Helper to Restore/Clone a Snapshot
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, HTableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, HTableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask, boolean) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RestoreSnapshotHelper.RestoreMetaChanges - Class in org.apache.hadoop.hbase.snapshot
-
Describe the set of operations needed to update hbase:meta after restore.
- resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
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
-
- ResultSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
- ResultSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- resume(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
- retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Assign regions to the previously hosting region server
- rethrowException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- rethrowException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- rethrowException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
In new mapreduce APIs, TaskAttemptContext has two getCounter methods
Check if getCounter(String, String) method is available.
- retrievePassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- ReversedKeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
-
ReversedKeyValueHeap is used for supporting reversed scanning.
- ReversedKeyValueHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- reverseDNS(InetAddress) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Deprecated.
mistakenly made public in 0.98.7. scope will change to package-private
- revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- 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
-
- rollback(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Remove n key from the memstore.
- rollback(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- rollback(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Remove n key from the memstore.
- rollback(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Deprecated.
use #rollback(Server, RegionServerServices, User)
- rollback(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Roll back a failed transaction
- rollback(RegionMergeTransaction, RegionMergeTransaction.RegionMergeTransactionPhase, RegionMergeTransaction.RegionMergeTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.TransactionListener
-
Invoked when rolling back a transaction from one transaction phase to the
previous
- rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- rollback(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- rollback(Server, RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Deprecated.
use #rollback(Server, RegionServerServices, User)
- rollback(Server, RegionServerServices, User) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Roll back a failed transaction
- rollback(SplitTransaction, SplitTransaction.SplitTransactionPhase, SplitTransaction.SplitTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.TransactionListener
-
Invoked when rolling back a transaction from one transaction phase to the
previous
- rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- rollback(Server, RegionServerServices, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- rollback(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Removes a Cell from the memstore.
- rollbackRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Roll back the global MemStore size for a specified region when this region
can't be opened.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- 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.FSHLog
-
- rollWriter(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- rollWriter() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rollWriter(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rootBlockContainingKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rootDir - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
- roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Perform a Round Robin assignment of regions.
- roundUpToBucketSizeInfo(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Round up the given block size to bucket size, and get the corresponding
BucketSizeInfo
- RowCounter - Class in org.apache.hadoop.hbase.mapred
-
A job with a map to count rows.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
-
- 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.mapreduce.RowCounter
-
- rowIsInRange(HRegionInfo, 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 HRegionInfo
- ROWKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- RowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Interface in org.apache.hadoop.hbase.regionserver
-
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
- RowProcessorClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
Convenience class that is used to make RowProcessorEndpoint invocations.
- RowProcessorClient() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
-
- RowTooBigException - Exception in org.apache.hadoop.hbase.regionserver
-
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).
- RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RowTooBigException
-
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- rowToStr(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
-
- RpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
- RpcExecutor(String, int) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- RpcExecutor(String, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- RpcExecutor.QueueBalancer - Class in org.apache.hadoop.hbase.ipc
-
- RpcExecutor.QueueBalancer() - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor.QueueBalancer
-
- rpcs - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- 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
-
- RpcScheduler.Context - Class in org.apache.hadoop.hbase.ipc
-
Exposes runtime information of a RpcServer
that a RpcScheduler
may need.
- RpcScheduler.Context() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
-
- RpcSchedulerFactory - Interface in org.apache.hadoop.hbase.regionserver
-
- 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) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer
-
Constructs a server listening on the named port and address.
- RpcServer.BlockingServiceAndInterface - Class in org.apache.hadoop.hbase.ipc
-
Datastructure for passing a BlockingService
and its associated class of
protobuf service interface.
- RpcServer.BlockingServiceAndInterface(BlockingService, Class<?>) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- RpcServer.Call - Class in org.apache.hadoop.hbase.ipc
-
Datastructure that holds all necessary to a method invocation and then afterward, carries
the result.
- RpcServer.CallQueueTooBigException - Exception in org.apache.hadoop.hbase.ipc
-
- RpcServer.Connection - Class in org.apache.hadoop.hbase.ipc
-
Reads calls from a connection and queues them for handling.
- RpcServer.Connection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- RpcServer.Responder - Class in org.apache.hadoop.hbase.ipc
-
- RpcServerInterface - Interface in org.apache.hadoop.hbase.ipc
-
- rpcServices - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- RSDumpServlet - Class in org.apache.hadoop.hbase.regionserver
-
- RSDumpServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSDumpServlet
-
- RSRpcServices - Class in org.apache.hadoop.hbase.regionserver
-
Implements the regionserver RPC services.
- RSRpcServices(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- rss - Variable in class org.apache.hadoop.hbase.regionserver.handler.FinishRegionRecoveringHandler
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- RSStatusServlet - Class in org.apache.hadoop.hbase.regionserver
-
- RSStatusServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSStatusServlet
-
- RSStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- RSStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- RSStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- RSStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmplImpl(TemplateManager, RSStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
-
- run() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- 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() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- run() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Responder
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- run(Mapper<ImmutableBytesWritable, Result, K2, V2>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Run the application's maps using a thread pool.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- run() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- run(String[]) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- run(String[]) - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- run(String[]) - Method in class org.apache.hadoop.hbase.migration.UpgradeTo96
-
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The HRegionServer sticks in this loop until closed.
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Execute the export snapshot by copying the snapshot metadata, hfiles and wals.
- run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- run() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- run(String[]) - Method in class org.apache.hadoop.hbase.tool.Canary
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.HFileV1Detector
-
Checks for HFileV1.
- run(String[]) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.ZKDataMigrator
-
- 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() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.WriterThread
-
- RUN_SHUTDOWN_HOOK - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for boolean configuration whose default is true.
- runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- RWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that uses different queues for reads and writes.
- RWQueueRpcExecutor(String, int, int, float, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, float, float, int) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, float, float, int, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, float, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, float, float, int, Configuration, Abortable, Class<? extends BlockingQueue>, Object...) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, int, int, Class<? extends BlockingQueue>, Object[], Class<? extends BlockingQueue>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- RWQueueRpcExecutor(String, int, int, int, int, float, Class<? extends BlockingQueue>, Object[], Class<? extends BlockingQueue>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- sanityCheckLeft(byte[], byte[], int, int) - 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[], byte[], int, int) - 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.
- 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 class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Scan data in a table.
- scan - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- 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_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_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_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The maximum number of version to return.
- 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_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.
- ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
-
This class is responsible for the tracking and enforcement of Deletes
during the course of a Scan operation.
- ScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Constructor for ScanDeleteTracker
- ScanInfo - Class in org.apache.hadoop.hbase.regionserver
-
Immutable information for scans over a store.
- ScanInfo(HColumnDescriptor, long, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- ScanInfo(byte[], int, int, long, KeepDeletedCells, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- ScanLabelGenerator - Interface in org.apache.hadoop.hbase.security.visibility
-
This would be the interface which would be used add labels to the RPC context
and this would be stored against the UGI.
- ScannerContext - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.Builder - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.LimitScope - Enum in org.apache.hadoop.hbase.regionserver
-
The various scopes where a limit can be enforced.
- ScannerContext.NextState - Enum in org.apache.hadoop.hbase.regionserver
-
- ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver
-
A query matcher that is specifically designed for the scan case.
- ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, ScanType, long, long, long, long, RegionCoprocessorHost) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Construct a QueryMatcher for a scan
- ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Construct a QueryMatcher for a scan that drop deletes from a limited range of rows.
- ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver
-
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- ScanType - Enum in org.apache.hadoop.hbase.regionserver
-
Enum to distinguish general scan types.
- ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
-
Keeps track of the columns for a scan if they are not explicitly specified
- ScanWildcardColumnTracker(int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Return maxVersions of every row.
- scopeWALEdits(HTableDescriptor, WALKey, WALEdit) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Utility method used to set the correct scopes on each log key.
- 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
-
- secretManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- SecureBulkLoadEndpoint - Class in org.apache.hadoop.hbase.security.access
-
Coprocessor service for bulk loads in secure mode.
- SecureBulkLoadEndpoint() - Constructor for class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- SecureProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- SecureProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- SecureWALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
A WALCellCodec that encrypts the WALedits.
- SecureWALCellCodec(Configuration, CompressionContext) - 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, Decryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecurityUtil - Class in org.apache.hadoop.hbase.security
-
Security related generic utility methods.
- SecurityUtil() - Constructor for class org.apache.hadoop.hbase.security.SecurityUtil
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
Set the scanner at the seek key.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Seeks all scanners at or below the specified seek key.
- seek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at or after the specified KeyValue.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- seek() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Advance the reader to the current position
- seek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- seek(long) - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- seekAsDirection(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Do a reseek in a normal StoreScanner(scan forward)
- seekAtOrAfter(HFileScanner, Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seekBefore(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekBefore(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekBefore(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekBefore(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekBefore(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekBefore(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Performs a filesystem-level seek to a certain position in an underlying file.
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- seekScanners(List<? extends KeyValueScanner>, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Seek the specified scanners with the given key
- seekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekTo(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
An internal API function.
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Positions this scanner at the start of the file.
- seekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Positions this scanner at the start of the file.
- seekToDataBlock(Cell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Return the data block which contains this key.
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- 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.StoreFileScanner
-
- seekToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
Separately get the KeyValue before the specified key from kvset and
snapshotset, and use the row of higher one as the previous row of
specified key, then seek to the first KeyValue of previous row
- seekToPreviousRow(Cell) - 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(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- select(List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Called to select files for compaction.
- selectCompaction(Collection<StoreFile>, List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- selectCompaction(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectFlush(StripeCompactionPolicy.StripeInformationProvider, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectScannersFrom(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.
- selectSingleStripeCompaction(StripeCompactionPolicy.StripeInformationProvider, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
- sendAbortToMembers(Procedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members that the coordinator has aborted the procedure and that it should release
barrier resources.
- sendAbortToMembers(Procedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
This is the abort message being sent by the coordinator to member
TODO this code isn't actually used but can be used to issue a cancellation from the
coordinator.
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members to acquire barrier for the procedure
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
The "acquire" phase.
- sendGlobalBarrierComplete() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendGlobalBarrierReached() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Sends a message to all members that the global barrier condition has been satisfied.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify members that all members have acquired their parts of the barrier and that they can
now execute under the global barrier.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- sendGlobalBarrierStart() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendMemberAborted(Subprocedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that we aborted the specified
Subprocedure
- sendMemberAborted(Subprocedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This should be called by the member and should write a serialized root cause exception as
to the abort znode.
- sendMemberAcquired(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has acquired the locally required
barrier condition.
- sendMemberAcquired(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This attempts to create an acquired state znode for the procedure (snapshot name).
- sendMemberCompleted(Subprocedure, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has completed the work that
needed to be done under the global barrier.
- sendMemberCompleted(Subprocedure, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This acts as the ack for a completed procedure
- sendRegionClose(ServerName, HRegionInfo, int, ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an CLOSE RPC to the specified server to close the specified region.
- sendRegionClose(ServerName, HRegionInfo, int) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- sendRegionOpen(ServerName, HRegionInfo, int, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendRegionOpen(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendRegionsMerge(ServerName, HRegionInfo, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an MERGE REGIONS RPC to the specified server to merge the specified
regions.
- sendRegionWarmup(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends a WARMUP RPC to the specified server to warmup the specified region.
- sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
If we have a response, and delay is not set, then respond
immediately.
- sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Called on stop/abort before closing the cluster connection and meta locator.
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
-
Comparator that compares based on the Sequence Ids of the
the StoreFiles.
- seqids - Static variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- SequenceFileLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SequenceFileLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- SequenceId - Interface in org.apache.hadoop.hbase.regionserver
-
Interface which abstracts implementations on log sequenceId assignment
- sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- sequenceIdChecker - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- serialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Serializes its data into destination.
- serialize(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
- serializeExtraInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- server - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- server - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
-
- server - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
-
- server - Variable in class org.apache.hadoop.hbase.master.BulkAssigner
-
- Server - Interface in org.apache.hadoop.hbase
-
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
- serverAdded(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server has joined the cluster.
- 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
-
- ServerConfigurationKeys - Interface in org.apache.hadoop.hbase.http
-
This interface contains constants for configuration keys used
in the hbase http server code.
- ServerListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of server events.
- ServerManager - Class in org.apache.hadoop.hbase.master
-
The ServerManager class manages info about region servers.
- ServerManager(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
-
Constructor.
- serverManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- ServerMetricsTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- ServerMetricsTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- ServerMetricsTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- ServerMetricsTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmplImpl(TemplateManager, ServerMetricsTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
-
- serverName - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- serverName - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The server name the Master sees us as.
- 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
-
- serverOffline(ZooKeeperWatcher, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A server is offline, all regions on it are dead.
- ServerRegionReplicaUtil - Class in org.apache.hadoop.hbase.util
-
- 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.
- servers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- servers - Variable in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- ServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
-
Process server shutdown.
- ServerShutdownHandler(Server, MasterServices, DeadServer, ServerName, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- service - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- service - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- services - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- services - Variable in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- services - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- services - Variable in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- set(long, TimeUnit) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Set the RateLimiter max available resources and refill period.
- setACL(AccessControlList) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Set the age of the last applied operation
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the age of the last edit that was shipped
- setAllowed(boolean) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setAppDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setArchiveTables(List<String>) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Set the tables to be archived.
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- 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
-
- setAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- setAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Sets given labels globally authorized for the user.
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Set the balancer on/off
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setBatchLimit(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setBindAddress(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.
- setBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setBulkLoaded(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setCacheOff() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Disables the tabledescriptor cache
- setCacheOff() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- setCacheOn() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Enables the tabledescriptor cache
- setCacheOn() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Switch for the background CatalogJanitor thread.
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Called after region is closed to notify all interesting parties / "register"
region as finally closed.
- setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
In ZK-based version we do some znodes transitioning.
- setClosing(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Exposed for some very specific unit tests.
- setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as down by deleting the znode.
- setClusterId(FileSystem, Path, ClusterId, int) - 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
- setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setClusterStatus(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the current cluster status.
- setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as up.
- setComparatorClass(Class<? extends KeyValue.KVComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Set compression context for this entry.
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- 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.master.balancer.BaseLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
This method should only be called once, as it starts a thread to keep the cache
up-to-date.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
Inform the policy that some configuration has been change,
so cached value should be updated it any.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration, ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.Canary
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- setConfig(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- setConfiguration(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Update the configuration for the
Constraint
; does not change the
order in which the constraint is run.
- setConfigure(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- setConflictWaitIterationMs(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- setConnection(String, int) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setConnection(String, int) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Registers current handler client details.
- setConnector(Connector) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setContext(HRegion.RowLockContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setCount(int) - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Set the current count to a new count
- setCurBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurrentCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- setCurTaskZKVersion(MutableInt) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setDeletedTable(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Mark table as deleted.
- setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Deletes the table in zookeeper.
- setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setDescription(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setDescription(String, String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Sets the region/store name, for logging.
- 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
-
Provide the configuration from the SplitLogManager
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Display the full report from fsck.
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Set the current thread local effective user
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
- setEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- 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
-
- setEntries(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setErr(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- 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
-
- 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.
- setExpectedVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- setFakeLookupMode(boolean) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- setFamilies(Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFilename(String) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFindPort(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- 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(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the first row
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Fix inconsistencies found by fsck.
- setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixTableLocks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Set table locks fix mode.
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixTableZNodes(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Set orphaned table ZNodes fix mode.
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setGlobalMemstoreLimit(long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Sets the global memstore limit to a new size.
- setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Deprecated.
Use setTable() instead.
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the HBase table.
- setIgnoreDeleteForTesting(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
Temporary function that is used by unit tests only
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setInfoFamilyCachingForMeta(HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Enable in memory caching for hbase:meta
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- 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(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(Configuration, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
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
-
- setIsMajor(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Specify if this compaction should be a major compaction based on the state of the store
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setKeytabConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLastQuery(long) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- 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(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the last row
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- setListener(EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- 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
-
- setLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
The function is used in SSH to set recovery mode based on configuration after all outstanding
log split tasks drained.
- setLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Allow that the log sequence id to be set post-construction and release all waiters on assigned
sequence number.
- setMajorRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
Sets compaction "major range".
- 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.
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the master service.
- setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMaxMemstoreTS(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- 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.
- setMemstoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setMerged(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setMinIndexNumEntries(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMWrap(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- setName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.
- setNamespace(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setNamespaceGroupPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
- setNamespaceQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceQuota(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceUserPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
- setNextPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the next pointer for the entry in the LRU.
- 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
-
- setNextState(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- setNextState(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- setNextState(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- setNextState(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- setNoStripeMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- 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.
- 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.
- setOffPeak(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- setOnlineRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the status code for the operation(Mutation) at the specified position.
- setOrigLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Used to set original seq Id for WALKey during wal replay
- setPathSpec(String[]) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- 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.
- setPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
- setPrevPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the previous pointer for the entry in the LRU.
- setPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Sets the priority for the request
- setPublishStatusInZk(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setQuota(MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- 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.
- setQuotas(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified namespace.
- setRackManager(RackManager) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setReason(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setRecovering(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Reset recovering state of current region
- setRecoveryMode(boolean) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Change the recovery mode.
- setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
This function is to set recovery mode from outstanding split log tasks from before or current
configuration setting
- setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
This function is to set recovery mode from outstanding split log tasks from before or current
configuration setting
- 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
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setRegionServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Set the list of region servers for that peer
- setRegionsToReopen(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Set the list of regions that will be reopened
because of an update in table schema
- setRequest(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- setResponse(Object, CellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- setRetainDays(int) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setRow(byte[], int, short) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Set current row
- 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
-
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered
- setRPC(String, Object[], long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPC(String, Object[], long) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Tells this instance that it is monitoring a new RPC call.
- setRPCPacket(Message) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPCPacket(Message) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gives this instance a reference to the protobuf received by the RPC, so
that it can later compute its size if asked for it.
- setSaslTokenResponse(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- 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.
- 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.
- setScanQueryMatcher(ScanQueryMatcher) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the list of
Scan
objects.
- setScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- 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
- setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServerName(ServerName) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
-
Sets server name on which opening operation is running.
- setServerName(ServerName) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSize(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setSizeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the size of the log queue
- setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setSnapshotHandlerForTesting(TableName, SnapshotSentinel) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Set the handler for the current snapshot
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Sets the socket buffer size used for responding to RPCs.
- setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setStatus(MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- setStatus(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setStoragePolicy(FileSystem, Configuration, Path, String, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets storage policy for given path according to config setting.
- setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
- setTableGroupPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
- setTableInfo(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableInfo(HBaseFsck.TableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setTableQuota(TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setTableState(TableName, ZooKeeperProtos.Table.State) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the table into desired state.
- setTableState(TableName, ZooKeeperProtos.Table.State) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Sets table state in ZK.
- setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the specified table into the newState, but only if the table is already in
one of the possibleCurrentStates (otherwise no operation is performed).
- setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks and sets table state in ZK.
- setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the specified table into the newState, but only if the table is NOT in
one of the possibleCurrentStates (otherwise no operation is performed).
- setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks and sets table state in ZK.
- setTableStateToDisabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabled
- setTableStateToDisabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabling
- setTableStateToEnabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabled
- setTableStateToEnabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabling
- setTableUserPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
- setTargetTableName(String[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setTaskNode(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setTEST_FORCE_REFRESH(boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- 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
-
- setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
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
-
- setTimeRangeTracker(TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Set TimeRangeTracker
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setTimestamp(byte[], int) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- setUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
- setup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.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<LongWritable, Text, ImmutableBytesWritable, Text>.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<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- setup(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Setup controller for the given region server.
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- setupClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Setup our cluster connection if not already initialized.
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupRegionReplicaReplication(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Create replication peer for replicating to region replicas if needed.
- 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
-
- setUsernameConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- 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
-
- setUserQuota(String, String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Set the value of this entry.
- setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- setVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- 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
- setVersionOfOfflineNode(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the walEdit for the operation(Mutation) at the specified position.
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
-
- setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
-
- shipBatch(long, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Convience method to apply changes to metrics do to shipping a batch of logs.
- shipEdits(boolean, List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the shipping logic
- shouldArchiveTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Determine if the given table should or should not allow its hfiles to be deleted in the archive
- shouldBeOnMaster(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Check if a region belongs to some small system table.
- shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- 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
-
- shouldCacheCompressed(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheDataCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- 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
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldComplete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIncludeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- 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
- shouldPrefetchOnOpen() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- 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.
- shouldReplayRecoveredEdits(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether to replay the recovered edits to flush the results.
- shouldSeek(Scan, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Check if this memstore may contain the required keys
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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
-
- shouldSplitWal - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- shouldUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, 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, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- shouldUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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.
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Specify if we have to shuffle the map tasks.
- shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Clean up the environment
- shutdown(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- shutdown() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Shutdown the cache.
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
No operation for the shutdown in the memory IO engine
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Close the file
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Shutdown the IOEngine
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- 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.LocalHBaseCluster
-
Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Shutdown the threadpool executor service
- shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- 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(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Closes catalog regions if open.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- shutdown() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- 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
-
- shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
-
Manage regionserver shutdown hooks.
- ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- 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
-
- signalAll() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- SimpleLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
Makes decisions about the placement and movement of Regions across
RegionServers.
- SimpleLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- SimpleRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
A scheduler that maintains isolated handler pools for general,
high-priority, and replication requests.
- SimpleRpcScheduler(Configuration, 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
-
- SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
- SimpleRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- SimpleScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
-
This is a simple implementation for ScanLabelGenerator.
- SimpleScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- 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
-
- SingletonCoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- sink - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- sinkToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sinkToString
- 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.bucket.BucketCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- size - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- size() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- size() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Gets the size (number of entries) of the map.
- size() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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.
- sizeIndex() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- sizeIndexOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- sizeOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- skippedEdits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- skipStoreFileRangeCheck() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- skipStoreFileRangeCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- sleeper - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Do the sleeping logic
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the sleeping logic
- slop - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- SMALL_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SMALL_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Triggers an asynchronous attempt to take a snapshot.
- snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- 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_IN_PROGRESS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
This tag will be created in in-progess snapshots
- snapshot_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- snapshot_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- 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_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
# of threads for snapshotting regions on the rs.
- SNAPSHOT_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for number of request threads to start snapshots on regionservers
- SNAPSHOT_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for millis between checks to see if snapshot completed or if there are errors
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Keep threads alive in request pool for max of 300 seconds
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for max time to keep threads in snapshot request pool waiting
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- 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
- SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
-
Filter that only accepts completed snapshot directories
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
- snapshotDisabledRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Take a snapshot of the specified disabled region
- SnapshotFileCache - Class in org.apache.hadoop.hbase.master.snapshot
-
Intelligently keep track of all the files for all the snapshots.
- SnapshotFileCache(Configuration, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem.
- SnapshotFileCache(FileSystem, Path, long, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem
- SnapshotFileCache.RefreshCacheTask - Class in org.apache.hadoop.hbase.master.snapshot
-
Simple helper task that just periodically attempts to refresh the cache
- SnapshotFileCache.RefreshCacheTask() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- SnapshotHFileCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
- SnapshotHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- 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
- 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.
- SnapshotLogCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a log cleaner that checks if a log is still used by
snapshots of HBase tables.
- SnapshotLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- SnapshotManager - Class in org.apache.hadoop.hbase.master.snapshot
-
This class manages the procedure of taking and restoring snapshots.
- SnapshotManager() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- SnapshotManager(MasterServices, MetricsMaster, ProcedureCoordinator, ExecutorService) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Fully specify all necessary components of a snapshot manager.
- snapshotManifest - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- SnapshotManifest - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help read/write the Snapshot Manifest.
- SnapshotManifestV1 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV2 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV2() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- 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
-
- SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
-
Utility methods for interacting with the snapshot referenced files.
- SnapshotReferenceUtil.SnapshotVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- SnapshotReferenceUtil.StoreFileVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
This method kicks off a snapshot procedure.
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Snapshot the specified regions
- SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
-
Watch the current snapshot under process
- snapshotTable - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- sniff(Admin, TableName) - Static method in class org.apache.hadoop.hbase.tool.Canary
-
Canary entry point for specified table.
- socket - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- solve() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Get the optimal assignments.
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SortedCopyOnWriteSet<E> - Class in org.apache.hadoop.hbase.util
-
Simple
SortedSet
implementation that uses an internal
TreeSet
to provide ordering.
- SortedCopyOnWriteSet() - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Collection<? extends E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- sourceScanner - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Source scanner that is tracking KV count; may be null if source is not StoreScanner
- sourceToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sourceToString
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split a pre-existing region into 2 regions.
- split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split an entire table.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- 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
-
- split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Divide 2 numbers in half (for split algorithm)
- 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_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
By default we retry errors in splitting, rather than skipping.
- SPLIT_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SPLIT_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SPLIT_TRANSACTION_IMPL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- splitCell - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(Set<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
This method is the base split method that splits WAL files matching a filter.
- SplitLogCounters - Class in org.apache.hadoop.hbase
-
Counters kept by the distributed WAL split log process.
- SplitLogCounters() - Constructor for class org.apache.hadoop.hbase.SplitLogCounters
-
- splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
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
-
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.
- splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable, LastSequenceId, CoordinatedStateManager, ZooKeeperProtos.SplitLogTask.RecoveryMode, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Splits a WAL file into region's recovered-edits directory.
- SplitLogManager - Class in org.apache.hadoop.hbase.master
-
Distributes the task of log splitting to the available region servers.
- SplitLogManager(Server, Configuration, Stoppable, MasterServices, ServerName) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Its OK to construct this object even when region-servers are not online.
- SplitLogManager.ResubmitDirective - Enum in org.apache.hadoop.hbase.master
-
- SplitLogManager.Task - Class in org.apache.hadoop.hbase.master
-
in memory state of an active task.
- SplitLogManager.Task() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- SplitLogManager.TaskBatch - Class in org.apache.hadoop.hbase.master
-
Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
- SplitLogManager.TaskBatch() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- SplitLogManager.TerminationStatus - Enum in org.apache.hadoop.hbase.master
-
- SplitLogManagerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordination for SplitLogManager.
- splitLogManagerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitLogManagerCoordination.SplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
-
Detail class that shares data between coordination and split log manager
- SplitLogManagerCoordination.SplitLogManagerDetails(ConcurrentMap<String, SplitLogManager.Task>, MasterServices, Set<String>, ServerName) - Constructor for class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- SplitLogTask - Class in org.apache.hadoop.hbase
-
State of a WAL log split during distributed splitting.
- SplitLogTask.Done - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Done(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
-
- SplitLogTask.Err - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Err(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
-
- SplitLogTask.Owned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Owned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Owned
-
- SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Resigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
-
- SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Unassigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Unassigned
-
- SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
-
This worker is spawned in every regionserver, including master.
- SplitLogWorker(Server, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker(Server, Configuration, RegionServerServices, LastSequenceId, WALFactory) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
-
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker
.
- SplitLogWorker.TaskExecutor.Status - Enum in org.apache.hadoop.hbase.regionserver
-
- SplitLogWorkerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
- splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitLogWorkerCoordination.SplitTaskDetails - Interface in org.apache.hadoop.hbase.coordination
-
Interface for log-split tasks Used to carry implementation details in encapsulated way through
Handlers to the coordination API.
- splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Specialized method to handle the splitting for meta WAL
- splitMetaLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Specialized method to handle the splitting for meta WAL
- splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Split a region on the region server.
- splits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
File Extension used while splitting an WAL into regions (HBASE-2312)
- SplitTransaction - Interface in org.apache.hadoop.hbase.regionserver
-
Executes region split as a "transaction".
- SplitTransaction.JournalEntry - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction journal entry
- SplitTransaction.SplitTransactionPhase - Enum in org.apache.hadoop.hbase.regionserver
-
Each enum is a step in the split transaction.
- SplitTransaction.TransactionListener - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction listener
- SplitTransactionCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordination operations for split transaction.
- splitTransactionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitTransactionCoordination.SplitTransactionDetails - Interface in org.apache.hadoop.hbase.coordination
-
Dummy interface for split transaction details.
- SplitTransactionFactory - Class in org.apache.hadoop.hbase.regionserver
-
A factory for creating SplitTransactions, which execute region split as a "transaction".
- SplitTransactionFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- SplitTransactionImpl - Class in org.apache.hadoop.hbase.regionserver
-
- SplitTransactionImpl(Region, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
Constructor
- SplitTransactionImpl.JournalEntryImpl - Class in org.apache.hadoop.hbase.regionserver
-
- SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase, long) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- SPNEGO_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- 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
-
- 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
-
- SslSelectChannelConnectorSecure - Class in org.apache.hadoop.hbase.jetty
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslSelectChannelConnectorSecure() - Constructor for class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
-
- SslSocketConnectorSecure - Class in org.apache.hadoop.hbase.http
-
This subclass of the Jetty SslSocketConnector exists solely to control
the TLS protocol versions allowed.
- SslSocketConnectorSecure() - Constructor for class org.apache.hadoop.hbase.http.SslSocketConnectorSecure
-
- start() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Start monitoring for archive updates
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- start() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Starts service.
- start() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- 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() - 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.http.HttpServer
-
Start the server.
- start() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- start() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- start(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- start() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Prepares for request serving.
- start() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Starts the service.
- start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
-
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
Deprecated.
- 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.procedure.flush.RegionServerFlushTableProcedureManager
-
Start accepting flush table requests.
- start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
- start(String, ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Initialize and start any threads or connections the member needs.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Start accepting procedure requests.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- start(ProcedureCoordinator) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Start monitoring znodes in ZK - subclass hook to start monitoring znodes they are about.
- start(String, ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- start() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- start() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- start(RpcScheduler) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- start(String) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Start a compaction.
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- start(ChoreService) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Start accepting snapshot requests.
- start() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
start the SplitLogWorker thread
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- start() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- start() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- start() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- start() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- start() - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- start() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- start() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
-
Starts the tracking of draining RegionServers.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Starts the tracking of online RegionServers.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- startAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- 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
-
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- 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.
- startcode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
This servers startcode.
- startConnectorServer(int, int) - Method in class org.apache.hadoop.hbase.JMXListener
-
- startDelay(boolean) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
Signal that the call response should be delayed, thus freeing the RPC
server to handle different requests.
- startDelay(boolean) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- startExecutorService(ExecutorType, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- startHandlers(String, int, List<BlockingQueue<CallRunner>>, int, int, int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- 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.
- startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Kick off the named procedure
Currently only one procedure with the same type and name is allowed to run at a time.
- startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Start the region merge transaction
- startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionOperation(Region.Operation) - 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 interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or
modifies data.
- startReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Start replication services.
- startReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
If replication is enabled and this cluster is a master,
it starts
- startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
init coordination for split transaction
- startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
- startup() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Initialize the environment
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- startup() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Start the replication
- startup(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
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
-
- startWriterThreads() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Called by the constructor to start the writer threads.
- startWriterThreads() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
Start the threads that will pump data from the entryBuffers to the output files.
- startWriting(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Starts writing into the block.
- state() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
-
- StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- statelessUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- 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
-
- StaticUserWebFilter.StaticUserFilter - Class in org.apache.hadoop.hbase.http.lib
-
- StaticUserWebFilter.StaticUserFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Record separator for the Bloom filter statistics human-readable string
- status - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- status - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The minimum time between two status messages, in milliseconds.
- STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The implementation class used to publish the status.
- std - Variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- STEPS_PER_REGION_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stepsAfterPONR(Server, RegionServerServices, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Deprecated.
- stepsAfterPONR(Server, RegionServerServices, HRegion, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
Deprecated.
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- StochasticLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
This is a best effort load balancer.
- StochasticLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- stop() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Stop this tracker and the passed zookeeper
- stop() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Stops service.
- stop() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- 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.ipc.FifoRpcScheduler
-
- 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 class org.apache.hadoop.hbase.ipc.RpcServer
-
Stops the service.
- stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
-
- stop() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- stop() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Stop the ServerManager.
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Close this and all running tasks
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Close this and all running procedure tasks
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- stop() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Close this and all running snapshot tasks
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
stop the SplitLogWorker thread
- stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- stop() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- stop() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- stop() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- stopAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- stopConnectorServer() - Method in class org.apache.hadoop.hbase.JMXListener
-
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- stopProcessingTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
called when Coordination should stop processing tasks and exit
- stopProcessingTasks() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Stops replication service.
- stopReplicationSinkServices() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
stop the thread pool executor.
- stopRequested - Variable in class org.apache.hadoop.hbase.regionserver.Leases
-
- 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
-
If the worker is doing a task i.e.
- store - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- Store - Interface in org.apache.hadoop.hbase.regionserver
-
Interface for objects that hold a column family in a Region.
- store - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- 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.
- storeConfigInfo - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- StoreConfigInformation - Interface in org.apache.hadoop.hbase.regionserver
-
A more restricted interface for HStore.
- StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends 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 - Class in org.apache.hadoop.hbase.regionserver
-
A Store data file.
- StoreFile(FileSystem, Path, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Constructor, loads a reader and it's indices, etc.
- StoreFile(FileSystem, StoreFileInfo, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Constructor, loads a reader and it's indices, etc.
- StoreFile(StoreFile) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Clone
- storeFile(HRegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor
-
- storeFile(String, String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
-
- StoreFile.Comparators - Class in org.apache.hadoop.hbase.regionserver
-
Useful comparators for comparing StoreFiles.
- StoreFile.Comparators() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
-
- StoreFile.Reader - Class in org.apache.hadoop.hbase.regionserver
-
Reader for a StoreFile.
- StoreFile.Reader(FileSystem, Path, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Reader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Writer - Class in org.apache.hadoop.hbase.regionserver
-
A StoreFile writer.
- StoreFile.WriterBuilder - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFile.WriterBuilder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- StoreFileInfo - Class in org.apache.hadoop.hbase.regionserver
-
Describe a StoreFile (hfile, reference, link)
- StoreFileInfo(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- StoreFileInfo(Configuration, FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- 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
- storeFileManager - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- StoreFileManager - Interface in org.apache.hadoop.hbase.regionserver
-
Manages the store files and basic metadata about that that determines the logical structure
(e.g.
- 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
-
- StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
-
KeyValueScanner adaptor over the Reader.
- StoreFileScanner(StoreFile.Reader, HFileScanner, boolean, boolean, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- storeFlusher - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- storeLimit - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- storeOffset - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- StoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the Store.
- StoreScanner(Store, boolean, Scan, NavigableSet<byte[]>, long, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
An internal constructor.
- StoreScanner(Store, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- StoreScanner(Store, ScanInfo, Scan, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for compactions.
- StoreScanner(Store, ScanInfo, Scan, 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_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreUtils - Class in org.apache.hadoop.hbase.regionserver
-
Utility functions for region server storage layer.
- StoreUtils() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- 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.
- StripeCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Stripe store implementation of compaction policy.
- StripeCompactionPolicy(Configuration, StoreConfigInformation, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- StripeCompactionPolicy.StripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Stripe compaction request wrapper.
- StripeCompactionPolicy.StripeCompactionRequest(CompactionRequest) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- StripeCompactionPolicy.StripeInformationProvider - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
The information about stripes that the policy needs to do its stuff
- StripeCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This is the placeholder for stripe compactor.
- StripeCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- StripeMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
Base class for cell sink that separates the provided cells into multiple files.
- StripeMultiFileWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- StripeMultiFileWriter.BoundaryMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on fixed row-key boundaries.
- StripeMultiFileWriter.BoundaryMultiWriter(List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- StripeMultiFileWriter.SizeMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on target cell number per file and file count.
- StripeMultiFileWriter.SizeMultiWriter(int, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- StripeMultiFileWriter.WriterFactory - Interface in 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
-
- 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
-
- StripeStoreFileManager - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFileManager.
- StripeStoreFileManager(KeyValue.KVComparator, Configuration, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- StripeStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFlusher.
- StripeStoreFlusher(Configuration, Store, StripeCompactionPolicy, StripeStoreFileManager) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- StripeStoreFlusher.BoundaryStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on boundaries.
- StripeStoreFlusher.BoundaryStripeFlushRequest(List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
-
- StripeStoreFlusher.SizeStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on size.
- StripeStoreFlusher.SizeStripeFlushRequest(int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
-
- StripeStoreFlusher.StripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper that writes a non-striped file.
- StripeStoreFlusher.StripeFlushRequest() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv>, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Submit an subprocedure for execution.
- submitTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- submitTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- Subprocedure - Class in org.apache.hadoop.hbase.procedure
-
Distributed procedure member's Subprocedure.
- Subprocedure(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure
-
- Subprocedure.SubprocedureImpl - Class in org.apache.hadoop.hbase.procedure
-
Empty Subprocedure for testing.
- Subprocedure.SubprocedureImpl(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- SubprocedureFactory - Interface in org.apache.hadoop.hbase.procedure
-
- subSet(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- subSet(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- subSet(E, E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- summarize() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
No operation for the sync in the memory IO engine
- sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Sync the data to file after writing
- sync() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Sync the data to IOEngine after writing
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- sync() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync what we have in the WAL.
- sync(long) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync the WAL if the txId was not already sync'd.
- sync() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- SYSTEM_LABEL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SystemTableWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Skips WAL edits for all System tables including META
- SystemTableWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
-
- table_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- table_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.table_jsp
-
- TABLE_LOCK_ENABLE - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
Configuration key for enabling table-level locks for schema changes
- TABLE_LOCK_EXPIRE_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
- TABLE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- TABLE_READ_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
Configuration key for time out for trying to acquire table locks
- TABLE_ROW_TEXTKEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Specify if the row key in table is text (ASCII between 32~126),
default is true.
- TABLE_WRITE_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
Configuration key for time out for trying to acquire table locks
- TableAddFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles adding a new family to an existing table.
- TableAddFamilyHandler(TableName, HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- TableAuthManager - Class in org.apache.hadoop.hbase.security.access
-
Performs authorization checks for a given user's assigned permissions
- TableCfWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
- TableCfWALEntryFilter(ReplicationPeer) - Constructor for class org.apache.hadoop.hbase.replication.TableCfWALEntryFilter
-
- tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A table is deleted.
- tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- tableDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Called after a table has been deleted, and after the table lock is released.
- TableDeleteFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles Deleting a column family from an existing table.
- TableDeleteFamilyHandler(TableName, byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- tableDescriptors - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Go here to get table descriptors.
- TableDescriptors - Interface in org.apache.hadoop.hbase
-
Get, remove and modify table descriptors.
- tableDict - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- TableEventHandler - Class in org.apache.hadoop.hbase.master.handler
-
Base class for performing operations against tables.
- TableEventHandler(EventType, TableName, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- tableHasErrors(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- TableHFileArchiveTracker - Class in org.apache.hadoop.hbase.backup.example
-
Track HFile archiving state changes in ZooKeeper.
- TableInputFormat - Class in org.apache.hadoop.hbase.mapred
-
Convert HBase tabular data into a format that is consumable by Map/Reduce.
- TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- 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.mapreduce.TableInputFormat
-
- TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
-
- TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
- TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- TableIntegrityErrorHandler - Interface in org.apache.hadoop.hbase.util.hbck
-
This interface provides callbacks for handling particular table integrity
invariant violations.
- 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 - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- tableLock - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- TableLockChecker - Class in org.apache.hadoop.hbase.util.hbck
-
Utility to check and fix table locks.
- TableLockChecker(ZooKeeperWatcher, HBaseFsck.ErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.hbck.TableLockChecker
-
- tableLockManager - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- TableLockManager - Class in org.apache.hadoop.hbase.master
-
A manager for distributed table level locks.
- TableLockManager() - Constructor for class org.apache.hadoop.hbase.master.TableLockManager
-
- tableLockManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- TableLockManager.NullTableLockManager - Class in org.apache.hadoop.hbase.master
-
A null implementation
- TableLockManager.NullTableLockManager() - Constructor for class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- TableLockManager.TableLock - Interface in org.apache.hadoop.hbase.master
-
A distributed lock for a table.
- 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.
- 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
-
- TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
-
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
-
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- TableModifyFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles adding a new family to an existing table.
- TableModifyFamilyHandler(TableName, HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- tableName - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- tablename - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- TableNamespaceManager - Class in org.apache.hadoop.hbase.master
-
This is a helper class used to manage the namespace
metadata that is stored in TableName.NAMESPACE_TABLE_NAME
It also mirrors updates to the ZK store by forwarding updates to
ZKNamespaceManager
- TableNamespaceManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- 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
-
- TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
-
Convert Map/Reduce output and write it to an HBase table
- TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- 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.mapreduce.TableOutputFormat
-
- TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
-
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable)
and write to an HBase table.
- TableOutputFormat.TableRecordWriter(BufferedMutator) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
Instantiate a TableRecordWriter with the HBase HClient for writing.
- TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
Writes the reducer output to an HBase table.
- TableOutputFormat.TableRecordWriter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
- TableProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
-
Procedures that operates on a specific Table (e.g.
- TableProcedureInterface.TableOperationType - Enum in org.apache.hadoop.hbase.master.procedure
-
- TableRecordReader - Class in org.apache.hadoop.hbase.mapred
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- 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.mapreduce.TableRecordReader
-
- TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapred
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- 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.mapreduce.TableRecordReaderImpl
-
- TableReduce<K extends org.apache.hadoop.io.WritableComparable,V> - Interface in org.apache.hadoop.hbase.mapred
-
Write a table, sorting by the input key
- 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
-
- TABLES_ON_MASTER - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- tablesDetailed_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- tablesDetailed_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
-
- TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
-
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
- TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- 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.mapreduce.TableSnapshotInputFormat
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapred
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor, HRegionInfo, List<String>) - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapreduce
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit(TableSnapshotInputFormatImpl.InputSplit) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor, HRegionInfo, List<String>) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- 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
-
- TableSnapshotInputFormatImpl.InputSplit - Class in org.apache.hadoop.hbase.mapreduce
-
Implementation class for InputSplit logic common between mapred and mapreduce.
- TableSnapshotInputFormatImpl.InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- TableSnapshotInputFormatImpl.InputSplit(HTableDescriptor, HRegionInfo, List<String>) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- TableSnapshotInputFormatImpl.RecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
Implementation class for RecordReader logic common between mapred and mapreduce.
- TableSnapshotInputFormatImpl.RecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- 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
-
Creates a TableSnapshotScanner.
- tablesOnMaster - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- tablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Check if configured to put any tables on the active master
- TableSplit - Class in org.apache.hadoop.hbase.mapred
-
A table split corresponds to a key range [low, high)
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
default constructor
- TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Constructor
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
- 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.mapreduce.TableSplit
-
Default constructor.
- TableSplit(byte[], Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- 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(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- 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.
- TableStateManager - Interface in org.apache.hadoop.hbase
-
Helper class for table state management for operations running inside
RegionServer or HMaster.
- TagRewriteCell - Class in org.apache.hadoop.hbase
-
This can be used when a Cell has to change with addition/removal of one or more tags.
- TagRewriteCell(Cell, byte[]) - Constructor for class org.apache.hadoop.hbase.TagRewriteCell
-
- tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- tailSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- tailSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- tailSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- take() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- takeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Take a snapshot based on the enabled/disabled state of the table.
- TakeSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
A handler for taking snapshots from the master.
- TakeSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- targets - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- taskLoop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
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.
- TaskMonitor - Class in org.apache.hadoop.hbase.monitoring
-
Singleton which keeps track of tasks going on in this VM.
- TaskMonitor() - Constructor for class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- taskMonitor - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- TaskMonitorTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmplImpl - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmplImpl(TemplateManager, TaskMonitorTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
-
- tasksInProgress - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- terminate(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- terminate(String, Exception) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- terminate(String, Exception, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- terminate(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
End the replication
- terminate(String, Exception) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
End the replication
- TEST_SKIP_SPLIT_HANDLING - Static variable in class org.apache.hadoop.hbase.master.AssignmentManager
-
For testing only! Set to true to skip handling of split.
- 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.
- 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.
- testTableCoprocessorAttrs(Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Sanity check the table coprocessor attributes of the supplied schema.
- TextSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits Sorted KeyValues.
- TextSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- ThreadMonitoring - Class in org.apache.hadoop.hbase.monitoring
-
- ThreadMonitoring() - Constructor for class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- threadWakeFrequency - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- thresholdIdleConnections - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- throttleCompaction(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- throttleCompaction(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- tickleOpening(OpenRegionCoordination.OpenRegionDetails, HRegionInfo, RegionServerServices, String) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Heartbeats to prevent timeouts.
- tickleOpening(OpenRegionCoordination.OpenRegionDetails, HRegionInfo, RegionServerServices, String) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
Update our OPENING state in zookeeper.
- TimeBasedLimiter - Class in org.apache.hadoop.hbase.quotas
-
Simple time based limiter that checks the quota Throttle
- timedOut(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- timeOfOldestEdit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
When was the last edit done in the memstore
- 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
- 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.
- timeoutInjector - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- TIMERANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Key for Timerange information in metadata
- timeRangeTracker - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- TimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
-
Stores the minimum and maximum timestamp values (both are inclusive).
- TimeRangeTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Default constructor.
- TimeRangeTracker(TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Copy Constructor
- TimeRangeTracker(long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- timestamp - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- TIMESTAMP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- TIMESTAMPKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- TimeToLiveHFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.
- TimeToLiveHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- TimeToLiveLogCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
Log cleaner that uses the timestamp of the wal to determine if it should
be deleted.
- TimeToLiveLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- tinfo - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- toArray() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- toArray() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- toByteArray() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- toContextString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- toFamilyString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- toJSON(String, NavigableSet<CachedBlock>) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- toJSON(BlockCacheUtil.CachedBlocksByFile) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- toJSON(BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- toJSON() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Creates a JSON object for parseable exposure of monitored tasks.
- TokenProvider - Class in org.apache.hadoop.hbase.security.token
-
Provides a service for obtaining authentication tokens via the
AuthenticationProtos
AuthenticationService coprocessor service.
- TokenProvider() - Constructor for class org.apache.hadoop.hbase.security.token.TokenProvider
-
- toMap() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- toMap() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Creates a string map of internal details for extensible exposure of
monitored tasks.
- toNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- toNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- toProtoUserInfo(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
- toRegion - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
-
- toServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
-
- toServer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
-
- toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- toString() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- toString() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- 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.io.FileLink
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- toString(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
- toString() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- 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.FixedFileTrailer
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- 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.Reference
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- 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.balancer.BaseLoadBalancer.Cluster.Action
-
- toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
-
- toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.MoveRegionAction
-
- toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.SwapRegionsAction
-
- toString() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- toString() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- toString() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- toString() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- toString() - Method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
- toString() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- 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.TimeBasedLimiter
-
- toString() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns String representation of the entry in form "key=value"
- toString() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- 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.TimeRangeTracker
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- toString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- toString() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- toString() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- toString() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- toString() - Method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
- toString() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- toString() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- toString() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- toString() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- toString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- toString() - Method in class org.apache.hadoop.hbase.util.IdLock.Entry
-
- toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- 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.WALKey
-
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- toStringClassDetails(StringBuilder) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- toStringDetailed() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- toStringFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toStringHeader(ByteBuffer) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Convert the contents of the block header into a human readable string.
- toStringLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toStringMap() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Produces a string map for this key.
- toStringMinusFileName(CachedBlock, long) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- tot_mgr_get_data_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_get_data_nonode - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_batch_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_batch_start - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_batch_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_start - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_log_split_success - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_missing_state_in_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_new_unexpected_wals - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_already_exists - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_create_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_create_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_create_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_create_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_delete_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_delete_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_node_delete_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_null_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_orphan_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_relist_logdir - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_rescan_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit_dead_server_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit_force - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit_threshold_reached - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_resubmit_unassigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_task_deleted - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_unacquired_orphan_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_mgr_wait_for_zk_delete - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_failed_to_grab_task_exception - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_failed_to_grab_task_lost_race - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_failed_to_grab_task_no_data - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_failed_to_grab_task_owned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_final_transition_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_get_data_queued - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_get_data_result - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_get_data_retry - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_preempt_task - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_acquired - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_acquired_rescan - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_done - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_err - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_grabing - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_heartbeat - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_heartbeat_failed - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- tot_wkr_task_resigned - Static variable in class org.apache.hadoop.hbase.SplitLogCounters
-
- totalByteSize - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- totalCompactedSize - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the total size of data processed by the currently running compaction, in bytes
- totalCompactingKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the total compacting key values in currently running compaction
- totalKeyCount - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
The total number of keys in all chunks
- totalKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Used for calculating the average key length.
- totalMaxKeys - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- totalUncompressedBytes - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Total uncompressed bytes, maybe calculate a compression ratio later.
- totalValueLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Used for calculating the average value length.
- TotesHRegionInfo - Interface in org.apache.hadoop.hbase.master.handler
-
Implementors tote an HRegionInfo instance.
- toUserInfo(RPCProtos.UserInformation) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
- trackTimestamps(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Record the earlest Put timestamp.
- trailer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- trailer - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- trailerSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- trailerWarnSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- 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.
- transition(RegionMergeTransaction, RegionMergeTransaction.RegionMergeTransactionPhase, RegionMergeTransaction.RegionMergeTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.TransactionListener
-
Invoked when transitioning forward from one transaction phase to another
- transition(SplitTransaction, SplitTransaction.SplitTransactionPhase, SplitTransaction.SplitTransactionPhase) - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.TransactionListener
-
Invoked when transitioning forward from one transaction phase to another
- transitionFromOfflineToOpening(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Transitions region from offline to opening state.
- transitionFromOfflineToOpening(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
Transition ZK node from OFFLINE to OPENING.
- transitionOpenFromPendingOpenOrOpeningOnServer(RegionTransition, RegionState, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Transition a region state to OPEN from OPENING/PENDING_OPEN
- transitionToOpened(HRegion, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Tries to move regions to OPENED state.
- transitionToOpened(HRegion, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
- trigger() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Trigger the timer immediately.
- triggerCacheRefreshForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Trigger a cache refresh, even if its before the next cache refresh.
- triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- triggerMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Trigger major compaction on all stores in the region.
- triggerMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- truncateTable(TableName, boolean, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- truncateTable(RpcController, MasterProtos.TruncateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- truncateTable(TableName, boolean, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Truncate a table
- TruncateTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Truncate the table by removing META and the HDFS files and recreating it.
- TruncateTableHandler(TableName, Server, MasterServices, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.TruncateTableHandler
-
- TruncateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- TruncateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- TruncateTableProcedure(MasterProcedureEnv, TableName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- trustStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- tryAcquire(long) - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
Acquire the lock within a wait time.
- tryAcquire(long) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Acquire the lock within a wait time.
- tryAcquireTableRead(TableName, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
Try to acquire the read lock on the specified table.
- tryAcquireTableWrite(TableName, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
Try to acquire the write lock on the specified table.
- tryAtomicRegionLoad(HConnection, byte[], byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- tryAtomicRegionLoad(Connection, TableName, byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Attempts to do an atomic load of many hfiles into a region.
- tryRegionServerReport(long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- tryTransitionFromOfflineToFailedOpen(RegionServerServices, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Tries transition region from offline to failed open.
- tryTransitionFromOfflineToFailedOpen(RegionServerServices, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
Try to transition to open.
- tryTransitionFromOpeningToFailedOpen(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Tries transition from Opening to Failed open.
- tryTransitionFromOpeningToFailedOpen(HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
This is not guaranteed to succeed, we just do our best.
- ts - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Timestamp for all inserted rows
- 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
-
- 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
-
- ttl - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- TTL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- TTL_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
-
- tune(HeapMemoryManager.TunerContext) - Method in interface org.apache.hadoop.hbase.regionserver.HeapMemoryTuner
-
Perform the heap memory tuning operation.
- tune(HeapMemoryManager.TunerContext) - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
-
- type - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
-
- type - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Validate the file to see if it even belongs in the directory.
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- validate(HBaseProtos.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.
- validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies root directory path is a valid URI with a scheme
- validateStoreFileName(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Validate the store file name.
- validateWALFilename(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- value - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The value
- value - Variable in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.ServerHostRegion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan.Position
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.Region.FlushResult.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.RegionMergeTransactionPhase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanQueryMatcher.MatchCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitTransactionPhase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.ServerHostRegion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan.Position
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.Region.FlushResult.Result
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.RegionMergeTransactionPhase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanQueryMatcher.MatchCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitTransaction.SplitTransactionPhase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyNSUpgrade(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- verifyRegionPlacement(boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Verify the region placement is consistent with the assignment plan
- VerifyReplication - Class in org.apache.hadoop.hbase.mapreduce.replication
-
This map-only job compares the data from a local table with a remote one.
- VerifyReplication() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- VerifyReplication.Verifier - Class in org.apache.hadoop.hbase.mapreduce.replication
-
Map-only comparator for 2 tables
- VerifyReplication.Verifier() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- VerifyReplication.Verifier.Counters - Enum in org.apache.hadoop.hbase.mapreduce.replication
-
- verifySnapshot(Path, Set<String>) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Verify that the snapshot in the directory is a valid snapshot
- verifySnapshot(Configuration, FileSystem, Path, HBaseProtos.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
- verifyUncompressed(ByteBuffer, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
An additional sanity-check in case no compression or encryption is being used.
- VERSION - Static variable in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- VERSION - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Current file format version
- VERSION - Static variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
The Bloom filter version.
- VERSION - Static variable in class org.apache.hadoop.hbase.wal.WALKey
-
- VersionInfoUtil - Class in org.apache.hadoop.hbase.client
-
Class to help with parsing the version info.
- VISIBILITY_EXP_RESOLVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- VISIBILITY_LABEL_GENERATOR_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- VISIBILITY_LABEL_SERVICE_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- VisibilityController - Class in org.apache.hadoop.hbase.security.visibility
-
Coprocessor that has both the MasterObserver and RegionObserver implemented that supports in
visibility labels
- VisibilityController() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- VisibilityController.VisibilityReplication - Class in org.apache.hadoop.hbase.security.visibility
-
A RegionServerObserver impl that provides the custom
VisibilityReplicationEndpoint.
- VisibilityController.VisibilityReplication() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- VisibilityExpEvaluator - Interface in org.apache.hadoop.hbase.security.visibility
-
During the read (ie.
- VisibilityExpressionResolver - Interface in org.apache.hadoop.hbase.mapreduce
-
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
- VisibilityLabelOrdinalProvider - Interface in org.apache.hadoop.hbase.security.visibility
-
- VisibilityLabelsCache - Class in org.apache.hadoop.hbase.security.visibility
-
Maintains the cache for visibility labels and also uses the zookeeper to update the labels in the
system.
- VisibilityLabelService - Interface in org.apache.hadoop.hbase.security.visibility
-
The interface which deals with visibility labels and user auths admin service as well as the cell
visibility expression storage part and read time evaluation.
- VisibilityLabelServiceManager - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityReplicationEndpoint - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityReplicationEndpoint(ReplicationEndpoint, VisibilityLabelService) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- VisibilityScanDeleteTracker - Class in org.apache.hadoop.hbase.security.visibility
-
Similar to ScanDeletTracker but tracks the visibility expression also before
deciding if a Cell can be considered deleted
- VisibilityScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- VisibilityUtils - Class in org.apache.hadoop.hbase.security.visibility
-
Utility method to support visibility
- VisibilityUtils() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- visitAllLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- visitAllLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Visits all table locks(read and write), and lock attempts with the given callback
MetadataHandler.
- visitLocks(InterProcessLock.MetadataHandler) - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
- visitLocks(InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Visits the locks (both held and attempted) with the given MetadataHandler.
- visitLogEntryBeforeWrite(HRegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- visitLogEntryBeforeWrite(HRegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
Called before each write.
- visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
- visitLogEntryBeforeWrite(HTableDescriptor, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot log files
- visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over hbase log files
- visitReferencedFiles(Configuration, FileSystem, Path, 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, HBaseProtos.SnapshotDescription, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files, restored.edits and logs
- visitRegionRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over recovered.edits of the specified region
- visitRegions(FileSystem, Path, FSVisitor.RegionVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the table store files
- visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the region store files
- visitTableRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over each region in the table and inform about recovered.edits
- visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the table store files
- 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(MasterProcedureEnv, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitFor(MasterProcedureEnv, long, long, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitForAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment.
- waitForAssignment(Collection<HRegionInfo>, boolean, int, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment, or the deadline is reached.
- waitForAssignment(Collection<HRegionInfo>, boolean, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment, or the deadline is reached.
- waitForCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForCompletedWithRet() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- waitForFlushesAndCompactions() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Wait for all current flushes and compactions of the region to complete
- waitForLatch(CountDownLatch, ForeignExceptionSnare, long, String) - Static method in class org.apache.hadoop.hbase.procedure.Procedure
-
Wait for latch to count to zero, ignoring any spurious wake-ups, but waking periodically to
check for errors
- waitForLocallyCompleted() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForMasterActive() - Method in class org.apache.hadoop.hbase.master.HMaster
-
If configured to put regions on active master,
wait till a backup master becomes active.
- waitForMasterActive() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- waitForPreviousTransactionsComplete() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Wait for all previous MVCC transactions complete
- waitForPreviousTransactionsComplete(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- waitForProcedureToComplete(ProcedureExecutor<MasterProcedureEnv>, long) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Get everything ready for region merge
- waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
Wait for the merging node to be transitioned from pending_merge
to merging by master.
- waitForRegionServers(MonitoredTask) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Wait for the region servers to report in.
- 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.
- waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
Wait while coordination process the transaction
- waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Wait for the splitting node to be transitioned from pending_split to splitting by master.
- waitForUpdate(long) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Wait for the state map to be updated by assignment manager.
- waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdLock
-
- waitingTimeForEvents - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- waitInterval() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- waitInterval(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- waitMetaRegions(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitOnMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop
Removes this thread from list of running threads.
- waitOnMaster(JVMClusterUtil.MasterThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop
Removes this thread from list of running threads.
- waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop
Removes this thread from list of running threads.
- waitOnRegionServer(JVMClusterUtil.RegionServerThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop
Removes this thread from list of running threads.
- waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Wait on region to clear regions-in-transition.
- waitOnRegionToClearRegionsInTransition(HRegionInfo, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Wait on region to clear regions-in-transition or time out
- waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Wait on region to clear regions-in-transition.
- 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.
- waitRegionInTransition(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- waitRegionInTransition(MasterProcedureEnv, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitRegionServers(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitUntilAssigned(Admin, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
Wait until bulk assign is done.
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Reopen the regions asynchronously, so always returns true immediately.
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- waitUntilDrained() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
-
- wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
frequency to check for errors (ms)
- wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
frequency to check for errors (ms)
- WAL - Interface in org.apache.hadoop.hbase.wal
-
A Write Ahead Log (WAL) provides service for reading, writing waledits.
- WAL.Entry - Class in org.apache.hadoop.hbase.wal
-
Utility class that lets us keep track of the edit with it's key.
- WAL.Entry() - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
-
- WAL.Entry(WALKey, WALEdit) - Constructor for class org.apache.hadoop.hbase.wal.WAL.Entry
-
Constructor for both params
- WAL.Reader - Interface in org.apache.hadoop.hbase.wal
-
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
- 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_FILE_NAME_DELIMITER - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
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_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
-
Get notification of WAL events.
- WALActionsListener.Base - Class in org.apache.hadoop.hbase.regionserver.wal
-
- WALActionsListener.Base() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.Base
-
- 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
.
- WALCellCodec.ByteStringCompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec.ByteStringUncompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec.EnsureKvEncoder - Class in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec.EnsureKvEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
-
- WALCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- 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
- WALEdit - Class in org.apache.hadoop.hbase.regionserver.wal
-
WALEdit: Used in HBase's transaction log (WAL) to represent
the collection of edits (KeyValue objects) corresponding to a
single transaction.
- WALEdit() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- WALEdit(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- WALEditsReplaySink - Class in org.apache.hadoop.hbase.regionserver.wal
-
This class is responsible for replaying the edits coming from a failed region server.
- WALEditsReplaySink(Configuration, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
-
Create a sink for WAL log entries replay
- WALEntryFilter - Interface in org.apache.hadoop.hbase.replication
-
A Filter for WAL entries before being sent over to replication.
- walFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- WALFactory - Class in org.apache.hadoop.hbase.wal
-
Entry point for users of the Write Ahead Log.
- WALFactory(Configuration, List<WALActionsListener>, String) - Constructor for class org.apache.hadoop.hbase.wal.WALFactory
-
- WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple
InputFormat
for
WAL
files.
- WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- WALKey - Class in org.apache.hadoop.hbase.wal
-
A Key for an entry in the change log.
- WALKey() - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey(byte[], TableName, long, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey.Version - Enum in org.apache.hadoop.hbase.wal
-
- 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
-
- 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.
- WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
-
A tool to replay WAL files as a M/R job.
- WALPlayer(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- WALPlayer.WALMapper - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that writes out
Mutation
to be directly applied to
a running HBase instance.
- WALPlayer.WALMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- 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.
- WALPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Fully specified constructor.
- WALProvider - Interface in org.apache.hadoop.hbase.wal
-
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
- WALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
-
- WALSplitter - Class in org.apache.hadoop.hbase.wal
-
This class is responsible for splitting up a bunch of regionserver commit log
files that are no longer being written to, into new files, one per region for
region to replay on startup.
- WALSplitter.EntryBuffers - Class in org.apache.hadoop.hbase.wal
-
Class which accumulates edits and separates them into a buffer per region
while simultaneously accounting RAM usage.
- WALSplitter.EntryBuffers(WALSplitter.PipelineController, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
-
- WALSplitter.MutationReplay - Class in org.apache.hadoop.hbase.wal
-
A struct used by getMutationsFromWALEntry
- WALSplitter.MutationReplay(ClientProtos.MutationProto.MutationType, Mutation, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.MutationReplay
-
- WALSplitter.OutputSink - Class in org.apache.hadoop.hbase.wal
-
The following class is an abstraction class to provide a common interface to support both
existing recovered edits file sink and region server WAL edits replay sink
- WALSplitter.OutputSink(WALSplitter.PipelineController, WALSplitter.EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- WALSplitter.PipelineController - Class in org.apache.hadoop.hbase.wal
-
Contains some methods to control WAL-entries producer / consumer interactions
- WALSplitter.PipelineController() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
-
- WALSplitter.RegionEntryBuffer - Class in org.apache.hadoop.hbase.wal
-
A buffer of some number of edits for a given region.
- WALSplitter.SinkWriter - Class in org.apache.hadoop.hbase.wal
-
Class wraps the actual writer which writes data out and related statistics
- WALSplitter.SinkWriter() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.SinkWriter
-
- WALSplitter.WriterThread - Class in org.apache.hadoop.hbase.wal
-
- WALSplitterHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles log splitting a wal
- WALSplitterHandler(Server, SplitLogWorkerCoordination, SplitLogWorkerCoordination.SplitTaskDetails, CancelableProgressable, AtomicInteger, SplitLogWorker.TaskExecutor, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
- WALUtil - Class in org.apache.hadoop.hbase.regionserver.wal
-
Helper methods to ease Region Server integration with the write ahead log.
- WALUtil() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
- warmupHRegion(HRegionInfo, HTableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- warmupRegion(RpcController, AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Wamrmup a region on this server.
- wasRegionOnDeadServerByMeta(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- watcher - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- webAppContext - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- webServer - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- whoAmI(RpcController, AuthenticationProtos.WhoAmIRequest, RpcCallback<AuthenticationProtos.WhoAmIResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- WINDOWS - Static variable in class org.apache.hadoop.hbase.util.FSUtils
-
Set to true on Windows platforms
- withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withMaxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withOutputDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withOutputStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- workingDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- WritableWithSize - Interface in org.apache.hadoop.hbase.io
-
An optional interface to 'size' writables.
- write(int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Transfers data from the given byte buffer to the buffer array
- write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Transfers data from the given byte buffer to file
- write(ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Transfers data from the given byte buffer to IOEngine
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- write(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Writes the Cell to this block
- write(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.Reference
-
- write(ImmutableBytesWritable, Put) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- write(ImmutableBytesWritable, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
Writes an action (Put or Delete) to the specified table.
- write(KEY, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Writes a key/value pair into the table.
- 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 class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Don't use these Writables methods. Use PB instead.
- write(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- write(String, String) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
-
- write(MBeanServer, ObjectName, String, boolean) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
-
- WRITE_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
ZNode prefix used by processes acquiring writer locks
- writeBlock(HFileBlock.BlockWritable, FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Takes the given
HFileBlock.BlockWritable
instance, creates a new block of
its appropriate type, writes the writable into this block, and flushes
the block into the output stream.
- writeBloom(DataOutput) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Writes just the bloom filter to the output array
- writeBulkLoadMarkerAndSync(WAL, HTableDescriptor, HRegionInfo, WALProtos.BulkLoadDescriptor, AtomicLong) - 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.
- writeCompactionMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.CompactionDescriptor, AtomicLong) - 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.
- writeFileInfo(FixedFileTrailer, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
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.
- writeFlushMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.FlushDescriptor, AtomicLong, boolean) - 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
- writeHeaderAndData(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- 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.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.
- writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- writeLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
-
Obtain a write lock containing given metadata.
- writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Returns a TableLock for locking the table for exclusive access
- writeLock(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
-
Obtain a write lock containing given metadata.
- writeMyEphemeralNodeOnDisk(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Logs the errors without failing on exception.
- writeNamespaceToZooKeeper(String, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- writePermissionsAsBytes(ListMultimap<String, TablePermission>, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Writes a set of permissions as Writable
instances
and returns the resulting byte array.
- writer - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- WriterBase - Class in org.apache.hadoop.hbase.regionserver.wal
-
Context used by our wal dictionary compressor.
- WriterBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- writeRegionEventMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.RegionEventDescriptor, AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a region open marker indicating that the region is opened
- writeRegionSequenceIdFile(FileSystem, Path, long, long) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a file with name as region open sequence id
- writerFactory - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Factory that is used to produce single StoreFile.Writer-s
- writers - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writersClosed - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writerThreads - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writeSingleLevelIndex(DataOutput, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Writes the block index data as a single level only.
- WriteSinkCoprocessor - Class in org.apache.hadoop.hbase.tool
-
This coprocessor 'shallows' all the writes.
- WriteSinkCoprocessor() - Constructor for class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- writeSnapshotInfo(HBaseProtos.SnapshotDescription, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Write the snapshot description into the working directory of a snapshot
- writeTableToZooKeeper(TableName, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- writeTime - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- writeToBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
Writes the block to the provided stream.
- writeToZookeeper(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
Write a table's access controls to the permissions mirror in zookeeper
- writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
Write a labels mirror or user auths mirror into zookeeper