|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
HFile readers.HFile writers.AccessController.FlushSnapshotSubprocedure.insideBarrier() step.
Constraint to the table with the given configuration
WALEdit.add(Cell) instead
AbstractHBaseTool.addOptWithArg(java.lang.String, java.lang.String)
and similar methods.
meta region.
RegionPlacementMaintainer to print
information for favored nodesAuthenticationTokenSecretManager.RpcExecutor that will balance requests evenly across all its queues, but still remains
efficient with a single queue via an inlinable queue balancing mechanism.HMaster.balance() when
needed.Constraint.ReplicationEndpoints.HRegion.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor, ?>, long, long) and Coprocessor endpoints.MultiVersionConsistencyControl.WriteEntry with a new write number.
BlockCacheHFile.
StoreFile.BucketAllocatorBucketAllocator to allocate/free block, and use
BucketCache.ramCache and BucketCache.backingMap in order to
determine if a given element is in the cache.conf.
Subprocedure when requested.
ByteBufferArrayCacheableDeserializerBucketAllocator.allocateBlock(int) when cache is full for
the requested sizeSubprocedure.acquireBarrier() and Subprocedure.insideBarrier() methods
while keeping some state for other threads to access.
RpcScheduler.Progressable but returns
a boolean to support canceling the operation.WALEntryFilter which contains multiple filters and applies them
in chain orderReadableByteChannel.read(java.nio.ByteBuffer).
WritableByteChannel.write(java.nio.ByteBuffer).
Put to ensure it is valid for the table.
HFile format version, and throws an exception if
invalid.
HRegionInfo from the snapshot region info.
HRegion.createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor)
requires.
outputStream (and so will close it).
LruBlockCache and BucketCache.MultiVersionConsistencyControl.WriteEntry that was created by MultiVersionConsistencyControl.beginMemstoreInsert().
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.HFile to the
CompoundBloomFilter class.Configuration instances.Import.CF_RENAME_PROP in conf that tells
the mapper how to rename column families.
RegionSplitPolicy implementation which splits a region
as soon as any of its store files exceeds a maximum configurable
size.Constraint (in traditional database terminology) to a HTable.Put.Constraints on a given table.Service instance via CoprocessorService.getService().DescriptiveStatistics.
RpcScheduler.
WALCellCodec from the cellCodecClsName and
CompressionContext, if cellCodecClsName is specified.
WALCellCodec from the
CompressionContext.
null and sets the environment in the new or existing instance.
StoreFile writing.
ServerManager.createDestinationServersList(org.apache.hadoop.hbase.ServerName) without server to exclude.
StoreFile writing.
JVMClusterUtil.MasterThread.
JVMClusterUtil.RegionServerThread.
CopyTable.createSubmittableJob(String[]) instead
HLog.Writer for writing log splits.
deletes from the hbase:meta table.
Constraint.
RegionSplitPolicy that disables region splits.BucketCache.Constraint.
BlockType.ENCODED_DATA.
TagType
.VISIBILITY_TAG_TYPE, that are part of the cell created from the WALEdits
that are prepared for replication while calling
ReplicationEndpoint
.replicate().
SplitLogManager to timeout the task node.
IllegalStateException otherwise.
Service method using
the registered protocol handlers.
FavoredNodeLoadBalancer that has all the intelligence
for racks, meta scans, etc.LoadBalancer that assigns favored nodes for
each region.RpcScheduler} that serves incoming requests in order.HFile has a fixed trailer which contains offsets to other
variable parts of the file.Durability.SKIP_WAL and the data is imported to hbase, we
need to flush all the regions of the table as the data is held in memory and is also not
present in the Write Ahead Log to replay in scenarios of a crash.
TableDescriptors that reads descriptors from the
passed filesystem.PathFilter that only allows directories.PathFilter that returns usertable directories.FileSystem
BlockType.ENCODED_DATA blocks from this file.
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods.
HConnection based on the environment in which we are running the
coprocessor.
LoadBalancer class.
HFile version.
HFile version 1: move this to StoreFile after Ryan's
patch goes in to eliminate KeyValue here.
HFile version.
HTable.
HTable.
WALEdit.getCells() instead
HFile version 1: move this to StoreFile after
Ryan's patch goes in to eliminate KeyValue here.
LoadBalancer class name.
BlockCacheUtil.CachedBlocksByFile instance and load it up by iterating content in
BlockCache.
Path object representing
the namespace directory under path rootdir
HLog.Reader for reading logs to split.
HLog.Reader for reading logs to split.
FileStatus of the file referenced by this StoreFileInfo
null if no credentials were provided.
null if no credentials were provided.
null if no user is set.
Scan.
Scan objects.
MultiTableSnapshotInputFormatImpl.RESTORE_DIRS_KEY)
MultiTableSnapshotInputFormatImpl.setSnapshotToScans(org.apache.hadoop.conf.Configuration, java.util.Map)
MultiTableSnapshotInputFormatImpl.setInput(org.apache.hadoop.conf.Configuration, java.util.Map, org.apache.hadoop.fs.Path)
Path object representing the table directory under
path rootdir
TableName object representing
the table directory under
path rootdir
HRegionServer.instantiateHLog(Path, String) setting up WAL instance.
path files.
HFile writers
HFile writers.
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.ForeignExceptionSnare.rethrowException().
Hash
ReplicationEndpoint implementation for replicating to another HBase cluster.BaseReplicationEndpoint for replication endpoints whose
target cluster is an HBase cluster.HFile.HFileStoreFiles)
for a HRegion from the FileSystem.HFile version 1 and 2 blocks, and writing version 2 blocks.HFileBlocks.HFile block writer.HFileBlockIndex.BlockIndexWriter) and read
(HFileBlockIndex.BlockIndexReader) single-level and multi-level block indexes.HFileOutputFormat2 instead.HFiles.HFile reader for version 2.HFileScanner interface.HFile reader for version 3.HFileScanner interface.HFile writer for version 3.InputFormat for HLog files.HRegion.startRegionOperation() to provide operation context for
startRegionOperation to possibly invoke different checks before any region operations.Put or
Delete instances)
passed to it out to the configured HBase table.Export.TableMapReduceUtil.initCredentialsForCluster(Job, Configuration) instead.
HFile.threadToJoin.
Filter to apply to all incoming keys (KeyValues) to
optionally not include in the job output
HRegionServer.setupWALAndReplication() creating WAL instance.
indices[i] represents the
randomized column index corresponding to randomized row index i,
create a new array with the corresponding inverted indices.
BucketCache.LoadBalancerTracker.
HFile that
does not do checksum verification in the file system
Set of KeyValues implemented on top of a
ConcurrentSkipListMap.HRegionInfo from the serialized version on-disk.
BaseHFileCleanerDelegate that only cleans HFiles that don't belong to a table that is
currently being archived.HeapSize,
memory-bound using an LRU eviction algorithm, and concurrent: backed by a
ConcurrentHashMap and with a non-blocking eviction thread giving
constant-time LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean) and LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean) operations.LruBlockCache.HMaster process.TablePermission matching up
to the column family portion of a permission.
MemStoreLAB.Chunk instances.Writables representing meta block data.
hbase:meta.hbase:metaHFile's mid-key.
HRegion.mutateRowsWithLocks(java.util.Collection, java.util.Collection)
and Coprocessor endpoints.MultiTableInputFormats..TableSnapshotInputFormat
allowing a MapReduce job to run over one or more table snapshots, with one or more scans
configured for each.TableSnapshotInputFormat
allowing a MapReduce job to run over one or more table snapshots, with one or more scans
configured for each.mutations against hbase:meta table.
Histogram instance.
Canary.Monitor.
HFileBlock.BlockIterator.nextBlock() but checks block type, throws an
exception if incorrect, and returns the HFile block
RegionObserver, MasterObserver, or WALObserver)
method.TableOutputFormat.setConf(Configuration).
HRegion.closeRegionOperation(Operation).
RegionObserver.postCompact(ObserverContext, Store, StoreFile, CompactionRequest)
instead
StoreFiles to compact have been selected from the available
candidates.
RegionObserver.postCompactSelection(ObserverContext, Store, ImmutableList,
CompactionRequest) instead.
StoreFiles to be compacted have been selected from the available
candidates.
HMaster deletes a
table.
RegionObserver.preFlush(ObserverContext, Store, InternalScanner) instead.
#postOpenDeployTasks(PostOpenDeployContext)
HRegion.startRegionOperation().
HMaster truncates a
table.
WALEdit
replayed for this region.
WALEdit
is writen to WAL.
StoreFiles selected for compaction into a new
StoreFile.
RegionObserver.preCompact(ObserverContext, Store, InternalScanner,
ScanType, CompactionRequest) instead
StoreFiles selected for compaction into a new
StoreFile and prior to creating the scanner used to read the input files.
RegionObserver.preCompactScannerOpen(ObserverContext, Store, List, ScanType, long,
InternalScanner, CompactionRequest) instead.
RegionObserver.preCompactScannerOpen(ObserverContext, Store, List, ScanType, long, InternalScanner, CompactionRequest)
StoreFiles to compact from the list of
available candidates.
RegionObserver.preCompactSelection(ObserverContext, Store, List, CompactionRequest)
instead
StoreFiles for compaction from the list of currently
available candidates.
HMaster.
HMaster.
HMaster.
HMaster deletes a
namespace
It can't bypass the default action, e.g., ctx.bypass() won't have effect.
HMaster deletes a
table.
HMaster deletes a
table.
RegionObserver.preFlush(ObserverContext, Store, InternalScanner) instead
RegionObserver.preFlushScannerOpen(ObserverContext,
Store, KeyValueScanner, InternalScanner)
HMaster process.
ObserverContext.bypass() has no
effect in this hook.
HMaster process.
RegionObserver.preStoreScannerOpen(ObserverContext,
Store, Scan, NavigableSet, KeyValueScanner)
HMaster truncates a
table.
HMaster truncates a
table.
WALEdit
replayed for this region.
WALEdit
is writen to WAL.
Subprocedure on a member.ps to the hbase:meta table.
HFile until the next
data block is found.
Writable instances
from the input stream.
HBaseProtos.SnapshotDescription stored for the snapshot in the passed directory
OutputFormat.
HRegion.HRegionServerHRegionServer.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.SplitAlgorithm for choosing region
boundaries.EventType.
Service subclass as a master coprocessor endpoint.
Service subclass as a coprocessor endpoint to
be available for handling
HRegion.execService(com.google.protobuf.RpcController,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall)} calls.
Service subclass as a coprocessor endpoint to
be available for handling
Constraints that have been added to the table
and turn off the constraint processing.
ReplicationEndpoint.replicate(ReplicateContext) method.SinkPeer as being bad (i.e.
SinkPeer successfully replicated a chunk of data.
KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) if forward is true) but only
does a seek operation after checking that it is really necessary for the
row/column combination specified by the kv parameter.
KeyValueScanner.seek(org.apache.hadoop.hbase.KeyValue) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.KeyValue) if forward is true) but only
does a seek operation after checking that it is really necessary for the
row/column combination specified by the kv parameter.
KeyValueHeap.seek(KeyValue) function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
key.
ForeignExceptionSnare.
SnapshotSentinel.getExceptionIfFailed().
RpcScheduler for
a region server.BlockingService and its associated class of
protobuf service interface.stdout.
ScanQueryMatcher.match(org.apache.hadoop.hbase.KeyValue) return codes.k[0] ..
- seekBefore(byte[], int, int) -
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>, KeyValue, 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, boolean) -
Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
- An internal API function.
- seekTo(byte[], int, int) -
Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- 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
- SeekTo or just before the passed
key.
- seekTo(byte[], int, int) -
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(byte[], int, int, HFileBlock, boolean, boolean, boolean) -
Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
- Return the data block which contains this key.
- 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.MemStore.MemStoreScanner
-
- 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(KeyValue) -
Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekToPreviousRow(KeyValue) -
Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
- Seek the scanner at the first KeyValue of the row which is the previous row
of specified key
- seekToPreviousRow(KeyValue) -
Method in class org.apache.hadoop.hbase.regionserver.MemStore.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(KeyValue) -
Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToPreviousRow(KeyValue) -
Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToPreviousRow(KeyValue) -
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.FIFOCompactionPolicy
-
- 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
-
- 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
- Sends a message to members that all
Subprocedure.insideBarrier() calls have completed.
- 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
- Sends a message to Members to create a new
Subprocedure for this Procedure and execute
the Subprocedure.acquireBarrier() step.
- 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) -
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) -
Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
- This acts as the ack for a completed snapshot
- 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.
- 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 -
Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- sequenceIdChecker -
Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- 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
-
- 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.BulkAssigner
-
- 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
-
- 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(String) -
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
-
- 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.
- 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.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 -
Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- set(int, E) -
Method in class org.apache.hadoop.hbase.util.SortedList
-
- setAdmin(HBaseAdmin) -
Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- 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
-
- 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
-
- 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.
- 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.HMaster
-
- 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
-
- 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
-
- 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
-
- 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.HLog.Entry
- Set compression context for this entry.
- setCompressionContext(CompressionContext) -
Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- setCompressionContext(CompressionContext) -
Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setConf(Configuration) -
Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- 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.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.AbstractHBaseTool
-
- 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.
- 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
- 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
-
- 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.
- 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
- Deprecated.
- setEndRow(byte[]) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- Deprecated.
- setEntries(List<HLog.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
-
- setEvictOnClose(boolean) -
Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
- Only used for testing.
- setExpiration(long) -
Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- setFakeLookupMode(boolean) -
Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- setFileInfoOffset(long) -
Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- 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
-
- 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
-
- setHFileCorruptionChecker(HFileCorruptionChecker) -
Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
- Deprecated. Allows subclasses to set the
HTable.
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- Deprecated.
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- Deprecated.
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
- Allows subclasses to set the
HTable.
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
- Sets the HBase table.
- setHTable(HTable) -
Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
- Sets the HBase table.
- 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
- setInput(Configuration, Map<String, Collection<Scan>>, Path) -
Static method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
- Configure conf to read from snapshotScans, with snapshots restored to a subdirectory of
restoreDir.
- setInput(JobConf, String, Path) -
Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
- Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, Map<String, Collection<Scan>>, Path) -
Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
-
- setInput(Configuration, Map<String, Collection<Scan>>, Path) -
Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- Configure conf to read from snapshotScans, with snapshots restored to a subdirectory of
restoreDir.
- setInput(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
- Deprecated.
- setInputColumns(byte[][]) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- Deprecated.
- setInputColumns(byte[][]) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- Deprecated.
- setIsMajor(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
- setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>) -
Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
- Store a collection of Map.Entry's in conf, with each entry separated by ','
and key values delimited by
ConfigurationUtil.KVP_DELIMITER
- setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>, char) -
Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
- Store a collection of Map.Entry's in conf, with each entry separated by ','
and key values delimited by delimiter.
- setLastContact(long) -
Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- setLastDataBlockOffset(long) -
Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- 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.
- 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.
- 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.LruBlockCache
-
- 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
-
- setMinFilesToCompact(int) -
Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
- Set upper bound on number of files to be included in minor compactions
- setMinThreshold(int) -
Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
- Overwrite min threshold for compaction
- setMServerWrap(MetricsHBaseServerWrapper) -
Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- setMWrap(MetricsRegionServerWrapper) -
Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- 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.
- 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.
- 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
- Deprecated. Sets the number of map tasks for the given job configuration to the
number of regions the given table has.
- setNumMovedMetaRegions(int) -
Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- setNumMovedRegions(int) -
Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- setNumReduceTasks(String, JobConf) -
Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
- Deprecated. Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setNumReduceTasks(String, Job) -
Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
- Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setNumRegions(int) -
Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- 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.
- setPosition(long) -
Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
- 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
- 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 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.regionserver.wal.HLogPrettyPrinter
- 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
-
- 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
- Deprecated. Allows subclasses to set the
Filter to be used.
- setRowFilter(Filter) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
- Deprecated.
- setRowFilter(Filter) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- Deprecated.
- setRowFilter(String) -
Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
- 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.
- 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
- Deprecated. 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.regionserver.wal.HLogKey
-
- setSecretManager(SecretManager<? extends TokenIdentifier>) -
Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setSequenceFilter(long) -
Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
- sets the region by which output will be filtered
- setSequenceID(long) -
Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- 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
-
- 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
-
- 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
-
- setSnapshotDirs(Configuration, Map<String, Path>) -
Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- setSnapshotHandlerForTesting(TableName, SnapshotSentinel) -
Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
- Set the handler for the current snapshot
- setSnapshotToScans(Configuration, Map<String, Collection<Scan>>) -
Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
- Push snapshotScans to conf (under the key
MultiTableSnapshotInputFormatImpl.SNAPSHOT_TO_SCANS_KEY)
- 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
- Deprecated.
- setStartRow(byte[]) -
Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
- Deprecated.
- setStatus(MonitoredRPCHandler) -
Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- setStatus(String) -
Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- 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
- setTableRecordReader(TableRecordReader) -
Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
- Deprecated. Allows subclasses to set the
TableRecordReader.
- setTableRecordReader(TableRecordReader) -
Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
- Allows subclasses to set the
TableRecordReader.
- setTableRecordReader(TableRecordReader) -
Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
- Allows subclasses to set the
TableRecordReader.
- 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
-
- 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
- setTimeRangeTracker(TimeRangeTracker) -
Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
- Set TimeRangeTracker
- setTotalUncompressedBytes(long) -
Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setUncompressedDataIndexSize(long) -
Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) -
Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
-
- 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(Mapper<ImmutableBytesWritable, Result, Import.KeyValueWritableComparable, KeyValue>.Context) -
Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) -
Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- 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(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
-
- setupJob(JobContext) -
Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- 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
-
- 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(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
- setVictimCache(BucketCache) -
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.
- setWALTrailer(WALProtos.WALTrailer) -
Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
- Sets HLog's WALTrailer.
- setWALTrailer(WALProtos.WALTrailer) -
Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- SEVENTY_FIFTH_PERCENTILE_METRIC_NAME -
Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
- Deprecated.
- 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<HLog.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
- 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 blocks of this HFile should be cached on read or not.
- 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.
- shouldDropBehind -
Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- shouldDropBehindCompaction() -
Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- 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.
- shouldSeek(Scan, long) -
Method in class org.apache.hadoop.hbase.regionserver.MemStore
- 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
-
- shouldSplitHlog -
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 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.MemStore.MemStoreScanner
-
- 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
-
- 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
-
- 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.DoubleBlockCache
- Deprecated.
- shutdown() -
Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- shutdown() -
Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
- Deprecated.
- shutdown() -
Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
- Deprecated. Sends a shutdown to all SingleSizeCache's contained by this cache.
- 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.HMaster
-
- 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.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
-
- 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
-
- SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
- Constructs a
SimpleRpcScheduler. - 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
-
- SingleSizeCache - Class in org.apache.hadoop.hbase.io.hfile.slab
- Deprecated. As of 1.0, replaced by
BucketCache. - SingleSizeCache(int, int, SlabItemActionWatcher) -
Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
- Deprecated. Default constructor.
- SingletonCoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
- Coprocessor endpoints registered once per server and providing protobuf services should implement
this interface and return the
Service instance via SingletonCoprocessorService.getService(). - sink -
Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- SINK_AGE_OF_LAST_APPLIED_OP -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- SINK_APPLIED_BATCHES -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- SINK_APPLIED_OPS -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- 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.DoubleBlockCache
- Deprecated.
- 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.slab.SingleSizeCache
- Deprecated.
- size() -
Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
- Deprecated.
- size() -
Method in class org.apache.hadoop.hbase.master.DeadServer
-
- size() -
Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- size() -
Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
- Gets the size (number of entries) of the map.
- 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.SortedCopyOnWriteSet
-
- size() -
Method in class org.apache.hadoop.hbase.util.SortedList
-
- 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
-
- skipLargeFiles(ArrayList<StoreFile>) -
Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- skipStoreFileRangeCheck() -
Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
- Deprecated. Use
RegionSplitPolicy.skipStoreFileRangeCheck(String)} instead
- skipStoreFileRangeCheck(String) -
Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
- See
RegionSplitPolicy.skipStoreFileRangeCheck() javadoc.
- SlabCache - Class in org.apache.hadoop.hbase.io.hfile.slab
- Deprecated. As of 1.0, replaced by
BucketCache. - SlabCache(long, long) -
Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
- Deprecated. Default constructor, creates an empty SlabCache.
- 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
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) -
Method in class org.apache.hadoop.hbase.master.HMaster
- Triggers an asynchronous attempt to take a snapshot.
- snapshot -
Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- 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_CONF_KEY -
Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- Version of the fs layout for new snapshot.
- SNAPSHOT_LAYOUT_LATEST_FORMAT -
Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- 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
- Deprecated. Use
SnapshotDescriptionUtils.DEFAULT_MAX_WAIT_TIME instead.
- 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
- Deprecated. Use
SnapshotDescriptionUtils.MASTER_SNAPSHOT_TIMEOUT_MILLIS instead.
- SNAPSHOT_TMP_DIR_NAME -
Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
- Temporary directory under the snapshot directory to store in-progress snapshots
- SNAPSHOT_TO_SCANS_KEY -
Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
- Utility class to help manage
SnapshotDesriptions. - 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(CatalogTracker) -
Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- SnapshotOfRegionAssignmentFromMeta(CatalogTracker, 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(HConnection, TableName, Canary.RegionTask.TaskType) -
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
-
- SortedList<E> - Class in org.apache.hadoop.hbase.util
- Simple sorted list implementation that uses
ArrayList as
the underlying collection so we can support RandomAccess. - SortedList(Comparator<? super E>) -
Constructor for class org.apache.hadoop.hbase.util.SortedList
- Constructs an empty list with the default initial capacity that will be
sorted using the given comparator.
- SortedList(Collection<? extends E>, Comparator<? super E>) -
Constructor for class org.apache.hadoop.hbase.util.SortedList
- Constructs a list containing the elements of the given collection, in the
order returned by the collection's iterator, that will be sorted with the
given comparator.
- SOURCE_AGE_OF_LAST_SHIPPED_OP -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_LOG_EDITS_FILTERED -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_LOG_EDITS_READ -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_LOG_READ_IN_BYTES -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_SHIPPED_BATCHES -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_SHIPPED_KBS -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_SHIPPED_OPS -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SOURCE_SIZE_OF_LOG_QUEUE -
Static variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- 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
- SPAN_RECEIVERS_CONF_KEY -
Static variable in class org.apache.hadoop.hbase.trace.SpanReceiverHost
-
- SpanReceiverHost - Class in org.apache.hadoop.hbase.trace
- This class provides functions for reading the names of SpanReceivers from
hbase-site.xml, adding those SpanReceivers to the Tracer, and closing those
SpanReceivers when appropriate.
- split(Path, Path, Path, FileSystem, Configuration) -
Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- 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
-
- 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 interface org.apache.hadoop.hbase.regionserver.wal.HLog
-
- 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 HLog 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, ZooKeeperWatcher, ZooKeeperProtos.SplitLogTask.RecoveryMode) -
Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
- Splits a HLog 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(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, ServerName, boolean) -
Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
- Wrapper around
SplitLogManager.SplitLogManager(ZooKeeperWatcher zkw, Configuration conf,
Stoppable stopper, MasterServices master, ServerName serverName,
boolean masterRecovery, TaskFinisher tf)
that provides a task finisher for copying recovered edits to their final destination.
- SplitLogManager(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, ServerName, boolean, SplitLogManager.TaskFinisher) -
Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
- Its OK to construct this object even when region-servers are not online.
- SplitLogManager.TaskFinisher - Interface in org.apache.hadoop.hbase.master
SplitLogManager can use objects implementing this interface to
finish off a partially done task by SplitLogWorker.- SplitLogManager.TaskFinisher.Status - Enum in org.apache.hadoop.hbase.master
- status that can be returned finish()
- 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 (should we also spawn one in
the master?).
- SplitLogWorker(ZooKeeperWatcher, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) -
Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker(ZooKeeperWatcher, Configuration, RegionServerServices, LastSequenceId) -
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
-
- splitMetaLog(ServerName) -
Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- Specialized method to handle the splitting for meta HLog
- splitMetaLog(Set<ServerName>) -
Method in class org.apache.hadoop.hbase.master.MasterFileSystem
- Specialized method to handle the splitting for meta HLog
- splitRegion(CatalogTracker, HRegionInfo, HRegionInfo, HRegionInfo, ServerName) -
Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
- Splits the region into two in an atomic operation.
- splitRegion(RpcController, AdminProtos.SplitRegionRequest) -
Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
- Split a region on the region server.
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, HTable, byte[], byte[]) -
Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- SPLITTING_EXT -
Static variable in interface org.apache.hadoop.hbase.regionserver.wal.HLog
- File Extension used while splitting an HLog into regions (HBASE-2312)
- SplitTransaction - Class in org.apache.hadoop.hbase.regionserver
- Executes region split as a "transaction".
- SplitTransaction(HRegion, byte[]) -
Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransaction
- Constructor
- 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(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.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(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(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() -
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
-
- startAndWait() -
Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- startCacheFlush(byte[]) -
Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
- WAL keeps track of the sequence numbers that were not yet flushed from memstores
in order to be able to do cleanup.
- startCatalogJanitorChore() -
Method in class org.apache.hadoop.hbase.master.HMaster
- Useful for testing purpose also where we have
master restart scenarios.
- 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.
- 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
- startRegionOperation() -
Method in class org.apache.hadoop.hbase.regionserver.HRegion
- This method needs to be called before any public call that reads or
modifies data.
- startRegionOperation(HRegion.Operation) -
Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionServer(HRegionServer) -
Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- startRegionServer(HRegionServer, String) -
Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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
- startThreads() -
Method in class org.apache.hadoop.hbase.ipc.RpcServer
- Starts the service threads but does not allow requests to be responded yet.
- startThreads() -
Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- 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.
- 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
-
- 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_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_DEV_METRIC_NAME -
Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
- Deprecated.
- stepsAfterPONR(Server, RegionServerServices, HRegion) -
Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
- Deprecated.
- stepsAfterPONR(Server, RegionServerServices, HRegion, User) -
Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<HRegion>) -
Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
- Deprecated.
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<HRegion>, User) -
Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
-
- stepsBeforePONR(Server, RegionServerServices, boolean) -
Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
- stepsBeforePONR(Server, RegionServerServices, boolean) -
Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
-
- 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
-
- StochasticLoadBalancer.CostFromRegionLoadFunction - Class in org.apache.hadoop.hbase.master.balancer
- Base class the allows writing costs functions from rolling average of some
number from RegionLoad.
- StochasticLoadBalancer.CostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Base class of StochasticLoadBalancer's Cost Functions.
- StochasticLoadBalancer.LoadPicker - Class in org.apache.hadoop.hbase.master.balancer
-
- StochasticLoadBalancer.LoadPicker() -
Constructor for class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer.LoadPicker
-
- StochasticLoadBalancer.LocalityCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute a cost of a potential cluster configuration based upon where
StoreFiles are located. - StochasticLoadBalancer.MemstoreSizeCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of total memstore size.
- StochasticLoadBalancer.MoveCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Given the starting state of the regions and a potential ending state
compute cost based upon the number of regions that have moved.
- StochasticLoadBalancer.ReadRequestCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of total number of read requests The more unbalanced the higher the
computed cost will be.
- StochasticLoadBalancer.RegionCountSkewCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of a potential cluster state from skew in number of
regions on a cluster.
- StochasticLoadBalancer.StoreFileCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of total open storefiles size.
- StochasticLoadBalancer.TableSkewCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of a potential cluster configuration based upon how evenly
distributed tables are.
- StochasticLoadBalancer.WriteRequestCostFunction - Class in org.apache.hadoop.hbase.master.balancer
- Compute the cost of total number of write requests.
- 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(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.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(String) -
Method in class org.apache.hadoop.hbase.master.HMaster
-
- 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.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(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.HMaster
-
- stopped -
Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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.HRegionServer
- Stop the region server.
- 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
- 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.
- 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
- Implements a
KeyValueScanner on top of the specified HFileScanner
- 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
-
- subList(int, int) -
Method in class org.apache.hadoop.hbase.util.SortedList
-
- 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
-
- submitSubprocedure(Subprocedure) -
Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
- Submit an subprocedure for execution.
- 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
- Task builder to build instances of a
ProcedureMember's Subprocedures. - subSet(KeyValue, KeyValue) -
Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- subSet(KeyValue, boolean, KeyValue, boolean) -
Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- 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
-
- switchBalancer(boolean, HMaster.BalanceSwitchMode) -
Method in class org.apache.hadoop.hbase.master.HMaster
- Assigns balancer switch according to BalanceSwitchMode
- 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 interface org.apache.hadoop.hbase.regionserver.wal.HLog
-
- sync(long) -
Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog
-
- sync() -
Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- sync() -
Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- synchronousBalanceSwitch(boolean) -
Method in class org.apache.hadoop.hbase.master.HMaster
-
- SyncTable - Class in org.apache.hadoop.hbase.mapreduce
-
- SyncTable(Configuration) -
Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- SyncTable.SyncMapper - Class in org.apache.hadoop.hbase.mapreduce
-
- SyncTable.SyncMapper() -
Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- SyncTable.SyncMapper.Counter - Enum in org.apache.hadoop.hbase.mapreduce
-
- 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
-
TableInputFormats.Mapper class to add the required input key
and value classes.TableMapper and TableReducerZKNamespaceManagerReducer class to add the required key and
value input/output classes.TableSplit.TableSplit(TableName, byte[], byte[], String)
TableSplit.TableSplit(TableName, byte[], byte[], String)
AuthenticationProtos AuthenticationService coprocessor service.LoadIncrementalHFiles.tryAtomicRegionLoad(HConnection, TableName, byte[], Collection)
EventType
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, KeyValue)
for details on this methods.
HFileBlock.
LruCachedBlock
VisibilityLabelServiceInterProcessLock.MetadataHandler.
MultiTableOutputFormat.WAL_OFF to turn off write-ahead logging (HLog)
FSHLog/WAL log events.Configuration.
FSHLog.StoreFile.WriterBuilder.withOutputDir(org.apache.hadoop.fs.Path), but not both.
StoreFile.WriterBuilder.withFilePath(org.apache.hadoop.fs.Path), but not both.
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.
HFileBlock.Writer.writeHeaderAndData(FSDataOutputStream), but records
the offset of this block so that it can be referenced in the next block
of the same type.
Writable instances
and returns the resulting byte array.
InterProcessReadWriteLock.ProcedureCoordinatorRpcs for a ProcedureCoordinatorZKProcedureMemberRpcs.start(String, ProcedureMember) before this can be used.
SplitLogManager and SplitLogWorker
running distributed splitting of WAL logs.
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||