- A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'A'
- a - Variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout.HeaderSize
-
- aarch64 - Static variable in class org.apache.hadoop.hbase.util.JVM
-
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
-
Abort the server or client.
- abort(String) - Method in interface org.apache.hadoop.hbase.Abortable
-
It just call another abort method and the Throwable parameter is null.
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- abort - Variable in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- abort(Thread, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- abort(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
Receive a notification and propagate it to the local coordinator
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Pass along the found abort notification to the listener
- abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.FailedProcedure
-
- abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The abort() call is asynchronous and each procedure must decide how to deal with it, if they
want to be abortable.
- abort(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Send an abort notification the specified procedure.
- abort(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Send an abort notification to the specified procedure.
- abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
-
- abort() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- abort - Variable in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- abort - Variable in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cause the server to exit without closing the regions it is serving, the log it is using and
without notifying the master.
- abort() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
Abort the snapshot preparation.
- abort() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Abort the snapshot preparation.
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.WarnOnlyAbortable
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- ABORT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ABORT_TIMEOUT_TASK - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- Abortable - Interface in org.apache.hadoop.hbase
-
Interface to support the aborting of a given server or client.
- abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortable - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- abortable - Variable in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- abortable - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- abortable - Variable in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
- abortable - Variable in class org.apache.hadoop.hbase.master.MasterRegionServerList
-
- abortable - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- abortable - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
-
- abortable - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
- abortable - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- abortable - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- abortable - Variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.RegionServerAddressTracker
-
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Used to abort if a fatal error occurs
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- abortAndThrowIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Abort a cache flush.
- aborted - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- aborted - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- aborted - Variable in class org.apache.hadoop.hbase.client.HBaseHbck
-
- aborted - Variable in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- aborted - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- aborted - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- abortMonitor - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abortOnError - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- abortOperationsInQueue() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.BufferNode
-
- abortPendingOperations(ServerName, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- abortPendingOperations(TRemote, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Abort a procedure.
- abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Abort the procedure with the given name
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- AbortProcedureFuture(HBaseAdmin, Long, Boolean) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.AbortProcedureFuture
-
- abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- abortProcess() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
-
triggered when the store is not able to write out data.
- abortRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abortServer(E, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortServer(String, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- abortWhenFail(ReplicationSourceManager.ReplicationQueueOperation) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- abortWriter(AbstractMultiFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
-
- abortWriter(T) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- abortWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
- abortWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Close all writers without throwing any exceptions.
- abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- ABOVE_HEAP_LOW_WATERMARK_COUNTER_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- ABOVE_HEAP_LOW_WATERMARK_COUNTER_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- aboveHeapOccupancyLowWatermarkCounter - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- AbstractByteRange - Class in org.apache.hadoop.hbase.util
-
An abstract implementation of the ByteRange API
- AbstractByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractByteRange
-
- AbstractClientScanner - Class in org.apache.hadoop.hbase.client
-
Helper class for custom client scanners.
- AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- AbstractDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
- AbstractDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
-
- AbstractDataBlockEncoder.AbstractEncodedSeeker - Class in org.apache.hadoop.hbase.io.encoding
-
- AbstractEncodedSeeker(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
-
- AbstractFileStatusFilter - Class in org.apache.hadoop.hbase.util
-
Typical base class for file status filter.
- AbstractFileStatusFilter() - Constructor for class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
- AbstractFSWAL<W extends WALProvider.WriterBase> - Class in org.apache.hadoop.hbase.regionserver.wal
-
Implementation of
WAL
to go against
FileSystem
; i.e.
- AbstractFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- AbstractFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- AbstractFSWAL.WalProps - Class in org.apache.hadoop.hbase.regionserver.wal
-
- AbstractFSWALProvider<T extends AbstractFSWAL<?>> - Class in org.apache.hadoop.hbase.wal
-
Base class of a WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
- AbstractFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- AbstractFSWALProvider.Reader - Interface in org.apache.hadoop.hbase.wal
-
- AbstractFSWALProvider.WALStartTimeComparator - Class in org.apache.hadoop.hbase.wal
-
Comparator used to compare WAL files together based on their start time.
- AbstractHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC client.
- AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, SecurityInfo, boolean) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, SecurityInfo, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- AbstractHBaseTool - Class in org.apache.hadoop.hbase.util
-
Common base class used for HBase command-line tools.
- AbstractHBaseTool() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- AbstractHBaseTool.OptionsOrderComparator - Class in org.apache.hadoop.hbase.util
-
- AbstractMemStore - Class in org.apache.hadoop.hbase.regionserver
-
An abstract class, which implements the behaviour shared by all concrete memstore instances.
- AbstractMemStore(Configuration, CellComparator, RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- AbstractMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
Base class for cell sink that separates the provided cells into multiple files.
- AbstractMultiFileWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
- AbstractMultiFileWriter.WriterFactory - Interface in org.apache.hadoop.hbase.regionserver
-
- AbstractMultiOutputCompactor<T extends AbstractMultiFileWriter> - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Base class for implementing a Compactor which will generate multiple output files after
compaction.
- AbstractMultiOutputCompactor(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
-
- AbstractPeerProcedure<TState> - Class in org.apache.hadoop.hbase.master.replication
-
The base class for all replication peer related procedure.
- AbstractPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- AbstractPeerProcedure(String) - Constructor for class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- AbstractPositionedByteRange - Class in org.apache.hadoop.hbase.util
-
- AbstractPositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- AbstractProcedureScheduler - Class in org.apache.hadoop.hbase.procedure2
-
- AbstractProcedureScheduler() - Constructor for class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- AbstractProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Base class for Protobuf log writer.
- AbstractProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- AbstractRecoveredEditsOutputSink - Class in org.apache.hadoop.hbase.wal
-
- AbstractRecoveredEditsOutputSink(WALSplitter, WALSplitter.PipelineController, EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
-
- AbstractRecoveredEditsOutputSink.RecoveredEditsWriter - Class in org.apache.hadoop.hbase.wal
-
Private data structure that wraps a
WALProvider.Writer
and its Path, also collecting
statistics about the data written to this output.
- AbstractResponse - Class in org.apache.hadoop.hbase.client
-
This class is used to extend AP to process single action request, like delete, get etc.
- AbstractResponse() - Constructor for class org.apache.hadoop.hbase.client.AbstractResponse
-
- AbstractResponse.ResponseType - Enum in org.apache.hadoop.hbase.client
-
- AbstractRpcBasedConnectionRegistry - Class in org.apache.hadoop.hbase.client
-
Base class for rpc based connection registry implementation.
- AbstractRpcBasedConnectionRegistry(Configuration, String, String, String, String) - Constructor for class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- AbstractRpcBasedConnectionRegistry.Callable<T> - Interface in org.apache.hadoop.hbase.client
-
For describing the actual asynchronous rpc call.
- AbstractRpcChannel(AbstractRpcClient<?>, Address, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
-
- AbstractRpcClient<T extends RpcConnection> - Class in org.apache.hadoop.hbase.ipc
-
Provides the basics for a RpcClient implementation like configuration and Logging.
- AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Construct an IPC client for the cluster clusterId
- AbstractRpcClient.AbstractRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
- AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
-
Blocking rpc channel that goes via hbase rpc.
- AbstractRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
-
Async rpc channel that goes via hbase rpc.
- AbstractSaslClientAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
- AbstractSaslClientAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.AbstractSaslClientAuthenticationProvider
-
- AbstractScreenView - Class in org.apache.hadoop.hbase.hbtop.screen
-
An abstract class for
ScreenView
that has the common useful methods and the default
implementations for the abstract methods.
- AbstractScreenView(Screen, Terminal) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- AbstractStateMachineNamespaceProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
-
Base class for all the Namespace procedures that want to use a StateMachineProcedure.
- AbstractStateMachineNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- AbstractStateMachineNamespaceProcedure(MasterProcedureEnv) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- AbstractStateMachineNamespaceProcedure(MasterProcedureEnv, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- AbstractStateMachineRegionProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
-
Base class for all the Region procedures that want to use a StateMachine.
- AbstractStateMachineRegionProcedure(MasterProcedureEnv, RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- AbstractStateMachineRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- AbstractStateMachineTableProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
-
Base class for all the Table procedures that want to use a StateMachineProcedure.
- AbstractStateMachineTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- AbstractStateMachineTableProcedure(MasterProcedureEnv) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- AbstractStateMachineTableProcedure(MasterProcedureEnv, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- AbstractViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
- AbstractViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- AbstractWALRoller<T extends Abortable> - Class in org.apache.hadoop.hbase.wal
-
Runs periodically to determine if the WAL should be rolled.
- AbstractWALRoller(String, Configuration, T) - Constructor for class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- AbstractWALRoller.RollController - Class in org.apache.hadoop.hbase.wal
-
Independently control the roll of each wal.
- accept(Void, Throwable) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ProcedureBiConsumer
-
- accept(Field, List<Field>, EnumMap<Field, Boolean>) - Method in interface org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener
-
- accept(AttributesBuilder) - Method in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
Deprecated.
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- accept(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFileWriterCreationTracker
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
Filters out a path.
- accept(FileStatus) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
- accept(FileStatus) - Method in interface org.apache.hadoop.hbase.util.FileStatusFilter
-
Tests whether or not the specified filestatus should be included in a filestatus list.
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.FileFilter
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
-
- accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- ACCEPT_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- ACCEPT_POLICY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
The strategy for handling new accepted connections.
- ACCEPT_QUEUE_SIZE_PER_THREAD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Maximum number of accepted elements per selector
- acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Acceptable size of cache (no evictions if size < acceptable)
- acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Acceptable size of cache (no evictions if size < acceptable)
- acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Acceptable size of cache (no evictions if size < acceptable)
- acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- acceptChannel - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- acceptInboundMessage(Object) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener.ClusterStatusHandler
-
- acceptPlan(HashMap<RegionInfo, RegionStateNode>, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
Block has been accessed.
- access(FileChannel, ByteBuff, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileAccessor
-
- access(FileChannel, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileReadAccessor
-
- access(FileChannel, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileWriteAccessor
-
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Block has been accessed.
- access(long) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
- ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- accessAclEntries - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- accessChecker - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- accessChecker - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- AccessChecker - Class in org.apache.hadoop.hbase.security.access
-
- AccessChecker(Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.AccessChecker
-
Constructor with existing configuration
- accessChecker - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
- AccessChecker.InputUser - Class in org.apache.hadoop.hbase.security.access
-
A temporary user class to instantiate User instance based on the name and groups.
- AccessControlClient - Class in org.apache.hadoop.hbase.security.access
-
Utility client for doing access control admin operations.
- AccessControlClient() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- AccessControlConstants - Interface in org.apache.hadoop.hbase.security.access
-
- AccessControlFilter - Class in org.apache.hadoop.hbase.security.access
-
NOTE: for internal use only by AccessController implementation
- AccessControlFilter() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
For Writable
- AccessControlFilter(AuthManager, User, TableName, AccessControlFilter.Strategy, Map<ByteRange, Integer>) - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- AccessControlFilter.Strategy - Enum in org.apache.hadoop.hbase.security.access
-
- AccessController - Class in org.apache.hadoop.hbase.security.access
-
Provides basic authorization checks for data access and administrative operations.
- AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
-
- AccessController.OpType - Enum in org.apache.hadoop.hbase.security.access
-
- accessControllerAvailable - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- AccessControlUtil - Class in org.apache.hadoop.hbase.security.access
-
- AccessControlUtil() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- accessCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache access count (sequential ID)
- accessCount - Variable in class org.apache.hadoop.hbase.mob.CachedMobFile
-
- accessCounter - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- accessCounter - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- accessDeniedClazz - Variable in class org.apache.hadoop.hbase.rest.ResourceBase
-
- AccessDeniedException - Exception in org.apache.hadoop.hbase.security
-
Exception thrown by access-related methods.
- AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- accessFile(FileIOEngine.FileAccessor, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- accessTime - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- accessUserTable(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Checks if the user has access to the full table or at least a family/qualifier for the
specified action.
- ack - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- ack - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- ack(boolean) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set ack/noAck mode.
- ackedBlockLength - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- ackedLength - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.Callback
-
- AckHandler(int) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.AckHandler
-
- ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Delimiter to separate user, column family, and qualifier in _acl_ table info: column keys
- ACL_LIST_FAMILY - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Column family used to store ACL grants
- ACL_NODE - Static variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- ACL_SYNC_TO_HDFS_ENABLE - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- ACL_SYNC_TO_HDFS_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Internal storage table for access control lists
- ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
KV tag to store per cell access control lists
- ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- aclEntry(AclEntryScope, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- aclRegion - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
flags if we are running on a region of the _acl_ table
- aclTabAvailable - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if the ACL table is available, only relevant in the master
- aclTableInitialized - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- aclType - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- AclType() - Constructor for enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType
-
- aclZNode - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- acquire() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- acquire() - Method in class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
Acquire the lock, waiting indefinitely until the lock is released or the thread is
interrupted.
- acquire() - Method in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- acquire(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
Called by the ProcedureExecutor to mark the procedure step as running.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Flush the online regions on this rs for the target table.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should gather and hold required resources (locks, disk space,
etc) to satisfy the Procedures barrier condition.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- acquireBufferQuota(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquiredBarrierLatch - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
latch for waiting until all members have acquire in barrier state
- acquireDelegationToken(FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Acquire the delegation token for the specified filesystem.
- acquireDelegationToken(String, FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Acquire the delegation token for the specified filesystem and token kind.
- acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- acquireLock(MasterProcedureEnv) - Method in interface org.apache.hadoop.hbase.master.locking.LockProcedure.LockInterface
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.NamespaceExclusiveLock
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.RegionExclusiveLock
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableExclusiveLock
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableSharedLock
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- acquireLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The user should override this method if they need a lock on an Entity.
- acquireLock(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
-
Return a lock for the given key.
- acquireLocks(Set<? extends K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
-
Acquire locks for a set of keys.
- acquireSlot() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- acquireSplitWALWorker(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
Acquire a split WAL worker
- acquiringMembers - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- act() - Method in interface org.apache.hadoop.hbase.master.cleaner.CleanerChore.Action
-
- Action - Class in org.apache.hadoop.hbase.client
-
A Get, Put, Increment, Append, or Delete associated with it's region.
- Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
- Action(Row, int, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
- Action(Action, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
Creates an action for a particular replica from original action.
- action - Variable in class org.apache.hadoop.hbase.client.Action
-
- action(AsyncAdminRequestRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- action(AsyncMasterRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- action(AsyncServerRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- action(AsyncSingleRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- action - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate
-
- action - Variable in class org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler.BufferCallEvent
-
- Action() - Constructor for enum org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
-
- action - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
-
- Action(char) - Constructor for enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- action2Errors - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- action2Future - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- actions - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- actions - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.RegionRequest
-
- actions - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- actions(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- actions - Variable in class org.apache.hadoop.hbase.client.BatchErrors
-
- actions - Variable in class org.apache.hadoop.hbase.client.DelayingRunner
-
- actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
-
A map of regions to lists of puts/gets/deletes for that region.
- actions - Variable in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
-
- actions - Variable in class org.apache.hadoop.hbase.security.access.Permission.Builder
-
- actionsByRegion - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
-
- actionsInProgress - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- active - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- active - Variable in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- active - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- ACTIVE_SCANNERS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- ACTIVE_SCANNERS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- ACTIVE_WORKER_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
- activeExecutorCount - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- activeFailoverTaskCount() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- activeHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- activeHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- activeMaster - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ActiveMasterManager - Class in org.apache.hadoop.hbase.master
-
Handles everything on master-side related to master election.
- ActiveMasterManager(ZKWatcher, ServerName, Server) - Constructor for class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- activeMasterManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- activeMasterServerName - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- ActiveOperation() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController.ActiveOperation
-
- activeOperations - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- activePolicies - Variable in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- ActivePolicyEnforcement - Class in org.apache.hadoop.hbase.quotas
-
A class to ease dealing with tables that have and do not have violation policies being enforced.
- ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices, SpaceViolationPolicyEnforcementFactory) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- activeProcedure - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
-
- activeReadHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- activeScanHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- activeTasks(SplitLogManager.TaskBatch) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- activeWorkerCountGauge - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- activeWriteHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- activeZKServerIndex - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- actualErrorRate() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Computes the error rate for this Bloom filter, taking into account the actual number of hash
functions and keys inserted.
- actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Computes the actual error rate for the given number of elements, number of bits, and number of
hash functions.
- actualLocalitySummary - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- actualPeerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- ADAPTIVE_COMPACTION_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- ADAPTIVE_COMPACTION_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- ADAPTIVE_INITIAL_COMPACTION_PROBABILITY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- ADAPTIVE_INITIAL_COMPACTION_PROBABILITY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- ADAPTIVE_PROBABILITY_FACTOR - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- AdaptiveLifoCoDelCallQueue - Class in org.apache.hadoop.hbase.ipc
-
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
- AdaptiveLifoCoDelCallQueue(int, int, int, double, LongAdder, LongAdder) - Constructor for class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- AdaptiveMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
-
Adaptive is a heuristic that chooses whether to apply data compaction or not based on the level
of redundancy in the data.
- AdaptiveMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Deprecated.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
-
Add column and value to this Append operation.
- add(Throwable, Row, ServerName) - Method in class org.apache.hadoop.hbase.client.BatchErrors
-
- add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- add(Map.Entry<byte[], List<Action>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
Add an existing delete marker to this Delete object.
- add(long) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
-
Add the specified KeyValue to this operation.
- add(byte[], Action) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], List<Action>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Add the pair to the container, grouped by the regionName.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified KeyValue to this Put operation.
- add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Currently only supports
Put
and
Delete
mutations.
- add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a list of mutations
- add(Configuration) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add Hadoop Configuration object to config list.
- add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add configuration-less constraints to the table.
- add(HTableDescriptor, Pair<Class<? extends Constraint>, Configuration>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add constraints and their associated configurations to the table.
- add(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add a
Constraint
to the table with the given configuration
- add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
nn * @return sum or non null value among (if either of them is null); otherwise returns a null.
- add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
This will add the distribution from input to this object
- add(Map.Entry<BlockCacheKey, BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.BucketEntryGroup
-
- add(Map.Entry<BlockCacheKey, BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Attempt to add the specified entry to this queue.
- add(byte[], long, int, long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Adds a new entry to this block index chunk.
- add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
Adds a new entry in the root block index.
- add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.BlockBucket
-
- add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.BlockBucket
-
- add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Attempt to add the specified cached block to this queue.
- add(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- add(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- add(List<String>) - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
- add(Queue<T>) - Method in class org.apache.hadoop.hbase.master.procedure.FairQueue
-
- add(Procedure<?>, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- add(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectAllVisitor
-
- add(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
-
- add(long, long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
Adds a value to the histogram.
- add(long, long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
Adds a value to the histogram.
- add(String) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Append the given message to this buffer, automatically evicting older messages until the
desired memory limit is achieved.
- add(RemoteProcedureDispatcher.RemoteProcedure) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.BufferNode
-
- add(RemoteProcedureDispatcher.RemoteProcedure<TEnv, TRemote>) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteNode
-
- add(DelayedUtil.DelayedWithTimeout) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
-
- add(ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- add(InlineChore) - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
-
- add(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
-
- add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds a value to the memstore
- add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds the specified value to the memstore
- add(Cell, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write an update n * @param memstoreSizing The delta in memstore size will be passed back via
this.
- add(Iterable<Cell>, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write the updates n * @param memstoreSizing The delta in memstore size will be passed back via
this.
- add(Cell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
-
Adds the given cell into the segment
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Add the specified cell to the list of deletes to check against for this row operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
Add the specified Cell to the list of deletes to check against for this row operation.
- add(Collection<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Add new store files.
- add(Collection<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Add a region model to the list
- add(TableModel) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
Add the table name model to the list
- add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker
-
- add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- add(Map.Entry<K, V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- add(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- add(V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Append field
to the sequence of accumulated fields.
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- add(Cell) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- add(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Concatenate byte arrays.
- add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Concatenate byte arrays.
- add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Concatenate byte arrays.
- add(long) - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- add(long) - Method in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- add(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Adds an edge to the split calculator
- add(T) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
-
- add(Iterator<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
-
- add(Stream<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
-
- add(E) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- add(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- add(Cell, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- add(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- add(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
Append the given map of family->edits to a WALEdit data structure.
- add(String, MutableMetric) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- add(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Add sample to a stat metric by name.
- add(long) - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- add(long) - Method in interface org.apache.hadoop.metrics2.MetricHistogram
-
Add a single value to a histogram's stream of values.
- addAction(HRegionLocation, Action) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
-
- addAction(ServerName, byte[], Action, Map<ServerName, MultiAction>, long) - Static method in class org.apache.hadoop.hbase.client.AsyncProcess
-
Helper that is used when grouping the actions per region server.
- addAll(Collection<? extends CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- addAll(Collection<? extends Map.Entry<K, V>>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- addAll(Collection<? extends K>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- addAll(Collection<? extends V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- addAll(int, Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- addAllHFiles() - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- addAllLogsToSysTable() - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batch
- addAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Adds the given servers to the group.
- addAllSublists(List<? extends List<T>>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- addAllToCorruptedAndRemoveFromProcMap(ProcedureTree.Entry, Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- addAllToValidAndRemoveFromProcMap(ProcedureTree.Entry, Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
-
- addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- addAndGet(Result[], boolean) - Method in interface org.apache.hadoop.hbase.client.ScanResultCache
-
Add the given results to cache and get valid results back.
- addAndReWatchTable(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Add this table to the tracker and then read a watch on that node.
- addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifier
-
Records a file and its size in bytes being moved to the archive directory.
- addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- addAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Add an attribute to the column family schema
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add an attribute to the table descriptor
- addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
-
- addAttributes(OperationWithAttributes, Map<ByteBuffer, ByteBuffer>) - Static method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Adds all the attributes into the Operation object
- addAttributes(OperationWithAttributes, Map<ByteBuffer, ByteBuffer>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Adds all the attributes into the Operation object
- addBack(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- addBack(Procedure, boolean) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- addBack(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Inserts the specified element at the end of this queue.
- addBack(Procedure, boolean) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Inserts the specified element at the end of this queue.
- addBatchToShippingQueue(WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
Update the batch try to ship and return true if shipped
- addBloomFilter(BloomFilterWriter, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- addByOne(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- addBytesMap(Map<Bytes, Bytes>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add Bytes map to config list.
- addCallsForCurrentReplica(ResultBoundedCompletionService<Pair<Result[], ScannerCallable>>) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- addCallsForOtherReplicas(ResultBoundedCompletionService<Pair<Result[], ScannerCallable>>, int, int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- addCallsForReplica(ResultBoundedCompletionService<Result>, RegionLocations, int, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
Creates the calls and submit them
- addCallSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- addCallSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Add/subtract from the current size of all outstanding calls.
- addCatalogReplicationSource(RegionInfo) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Add an hbase:meta Catalog replication source.
- addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
Adds a cell to the list of cells for this row
- addCell(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- addCellCount(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- addCellPermissions(byte[], Map<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
-
- addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- addChildExp(ExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- addChildExps(List<ExpressionNode>) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- addChildProcedure(T...) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Add a child procedure to execute
- addChore(ProcedureInMemoryChore<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a chore procedure to the executor
- addClickjackingPreventionFilter(ServletContextHandler, Configuration) - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- addClientMetris(UserMetrics.ClientMetrics) - Method in class org.apache.hadoop.hbase.UserMetricsBuilder
-
- addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Add a client port to the list.
- addClusterId(UUID) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Marks that the cluster with the given clusterId has consumed the change
- addColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the latest version of the specified column.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the specified version of the specified column.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get the column from the specific family with the specified qualifier.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Increment the column from the specific family with the specified qualifier by the specified
amount.
- addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value to this Put operation.
- addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as its version to this Put
operation.
- addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as its version to this Put
operation.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the column from the specified family with the specified qualifier.
- addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- addColumn(Scan, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Parses a combined family and qualifier and adds either both or just the family in case there is
no qualifier.
- addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Add a new column to an existing table
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Add a column to the column set
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a column family to an existing table.
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- addColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add a column family to the table descriptor
- addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- addColumnFamily(TTableName, TColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a column family to an existing table.
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- AddColumnFamilyFuture(HBaseAdmin, TableName, MasterProtos.AddColumnResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.AddColumnFamilyFuture
-
- AddColumnFamilyProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.AddColumnFamilyProcedureBiConsumer
-
- addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column.
- addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column with a timestamp less than or equal to the
specified timestamp.
- addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Adds an array of columns specified using old format, family:qualifier.
- addColumns(Scan, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Convenience method to parse a string representation of an array of column specifiers.
- addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds only the new compaction results into the structure.
- addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- addConfig(RegionServerStatusProtos.RegionServerStartupResponse.Builder, String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addConnection(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
-
Deprecated.
Updating the readSelector while it's being used is not thread-safe, so the connection must
be queued.
- addConstraint(HTableDescriptor, Class<? extends Constraint>, Configuration, long) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Write the raw constraint and configuration to the descriptor.
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Add a table coprocessor to this table.
- addCostFuncInfo(String, double, float) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
-
- addCostFunction(CostFunction) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- addCostumHeader(String, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.HTTPThriftClientBuilder
-
- addCounter(String, Counter, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
- addCounter(MetricsRecordBuilder, Map<String, Long>, String, String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- addCSRFFilter(ServletContextHandler, Configuration) - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- addCurrentScanners(List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- addDaughtersToPut(Put, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds split daughters to the Put
- addDeadNode(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a dead node to the cluster representation.
- addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add default apps.
- addDefaultServlets(ContextHandlerCollection, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add default servlets.
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store delete family Bloom filter in the file, which is only supported in HFile V2.
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
Deprecated.
- addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the HBase dependency jars as well as jars for any of the configured job classes to the job
configuration, so that JobClient will ship them to the cluster and add them to the
DistributedCache.
- addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- addDependencyJarsForClasses(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the jars containing the given classes to the job's configuration such that JobClient will
ship them to the cluster and add them to the DistributedCache.
- addDeprecatedKeys() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
The hbase.ipc.server.reservoir.initial.max and hbase.ipc.server.reservoir.initial.buffer.size
were introduced in HBase2.0.0, while in HBase3.0.0 the two config keys will be replaced by
hbase.server.allocator.max.buffer.count and hbase.server.allocator.buffer.size.
- addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addend - Static variable in class org.apache.hadoop.hbase.util.Random64
-
- addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Add an endpoint that the HTTP server should listen to.
- addEntry(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Add one index entry to the current leaf-level block.
- addEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Adds an entry to the dictionary.
- addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- addEntry(WAL.Entry, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- addEntryInternal(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- addEntryToBatch(WALEntryBatch, WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- addError(Action, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- addError(Iterable<Action>, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- addError() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker.ServerErrors
-
- addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- addExplicitProviders(Configuration, HashMap<Byte, SaslClientAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Extracts and instantiates authentication providers from the configuration.
- addExtendedAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Add a named String value to this WALKey to be persisted into the WAL
- addExtendedAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Add extra headers.
- addExtraParam(String, String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- addExtraProviders(Configuration, HashMap<Byte, SaslServerAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Adds any providers defined in the configuration.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of all columns of the specified family.
- addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp less than or equal to the specified
timestamp.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get all columns from the specified family.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all columns from the specified family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Adds a column family.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- addFamilyAndItsHFilePathToTableInMap(byte[], String, List<Pair<byte[], List<String>>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- addFamilyStoreFile(String, String) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
-
- addFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp equal to the specified timestamp.
- addFile(List<FileStatus>, LocatedFileStatus, long, long) - Static method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Add a filter.
- addFilter(String, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- addFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
-
Add a filter to the container.
- addFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Add a Filter to be instantiated on import
- addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
- addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
- addFilterPathMapping(String, WebAppContext) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add the path spec to the filter path mapping.
- addFirst(ImmutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- addFront(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- addFront(Procedure, boolean) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- addFront(Iterator<Procedure>) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- addFront(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Inserts the specified element at the front of this queue.
- addFront(Procedure, boolean) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Inserts the specified element at the front of this queue.
- addFront(Iterator<Procedure>) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Inserts all elements in the iterator at the front of this queue.
- addGauge(String, Gauge<?>, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
- addGauge(MetricsRecordBuilder, Map<String, Long>, String, String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- addGaugesToMetricsRecordBuilder(MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- addGeneralBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store general Bloom filter in the file.
- addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- addGetResult(Result) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a get result.
- addGlobalFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
-
Add a global filter to the container - This global filter will be applied to all available web
contexts.
- addGlobalFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add HBase and its dependencies (only) to the job configuration.
- addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- addHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Add hfile names to the queue to be replicated.
- addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- addHFileRefs(String, List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Add new hfile references to the queue.
- addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- addHFileRefsToQueue(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- addHistogram(String, Histogram, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
Add Histogram value-distribution data to a Hadoop-Metrics2 record building.
- addHole(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- addHostAndBlockWeight(String, long, long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to a specific host
- addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to a list of hosts, update the value of unique block weight
- addHostsAndBlockWeight(String[], long, StorageType[]) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to a list of hosts, update the value of unique block weight
- addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
- addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Adds a security configuration for a new service name.
- addInlineBlockWriter(InlineBlockWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Adds an inline block writer such as a multi-level block index writer or a compound Bloom
filter writer.
- addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- addInternalServlet(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server, specifying whether or not to protect with Kerberos
authentication.
- addInternalServlet(String, ServletHolder, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server, specifying whether or not to protect with Kerberos
authentication.
- additionalLoadOnOpenData - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Additional data items to be written to the "load-on-open" section.
- addJerseyResourcePackage(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a Jersey resource package.
- addJitter(long, float) - Static method in class org.apache.hadoop.hbase.util.RetryCounter
-
- addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- addLabel(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Add a visibility label to the scan
- addLabel(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Deprecated.
- addLabel(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding label to the system.
- addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addLabels(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Deprecated.
- addLabels(Connection, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding labels to the system.
- addLabels(RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
VisibilityEndpoint service related methods
- addLabels(List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Adds the set of labels into the system.
- addLast(Procedure<?>) - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.BloomContext
-
Adds the last bloom key to the HFile Writer as part of StorefileWriter close.
- addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowBloomContext
-
- addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowColBloomContext
-
- addLastSeqIdsToOps(String, Map<String, Long>, List<ZKUtil.ZKUtilOp>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- addLease(LeaseManager.Lease) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Inserts lease.
- addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
Listen for failures to a given process.
- addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
This is method is used when you just want to add a listener to the given future.
- addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>, Executor) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
- addListener(Future<V>, GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
This is method is used when you just want to add a listener to the given netty future.
- addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a live node to the cluster representation.
- addLocation(Put, ServerName, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
- addLocationsOrderInterceptor(Configuration, HFileSystem.ReorderBlocks) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Add an interceptor on the calls to the namenode#getBlockLocations from the DFSClient linked to
this FileSystem.
- addLocationToCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- addLocationToCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- addLogFile(String, String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Add the specified log file to the stats
- addManagedListener(ServerConnector) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- addMergeRegions(Put, Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addMetaData(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Adds metadata at current position (position is moved forward).
- addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- addMeter(String, Meter, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
Add Dropwizard-Metrics rate information to a Hadoop-Metrics2 record builder, converting the
rates to the appropriate unit.
- addMethod(String, String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
-
- addMethod(String, Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
-
- addMethod(Method) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
-
- addMethods() - Method in class org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods
-
- addMethods(Class<?>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods
-
- addMobRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- addMobRegion(RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- addMultiException(MultiException, Exception) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- addMutation(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a mutation result.
- addMvccToOperationContext(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Store the write point in OperationContext when the operation succeed.
- addNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- addNamespace(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- addNamespaceQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addNamespaceQuotaTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Adds a table with a namespace quota.
- addNewMetricIfAbsent(String, T, Class<T>) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- addNewRegions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- addNewTableEntryInMap(Map<String, List<Pair<byte[], List<String>>>>, byte[], String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- addNoCacheFilter(WebAppContext) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
- addNode(TRemote) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
Add a node that will be able to execute remote procedures
- addOperationsFromCP(int, Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Add more Mutations corresponding to the Mutation at the given index to be committed atomically
in the same batch.
- addOperationToNode(TRemote, RemoteProcedureDispatcher.RemoteProcedure) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
Add a remote rpc.
- addOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- addOptions() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- addOptions() - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- addOptions() - Method in class org.apache.hadoop.hbase.procedure2.store.region.WALProcedurePrettyPrinter
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- addOptions(Options) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Add options to command lines
- addOptions(Options) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- addOptions() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- addOptions() - Method in class org.apache.hadoop.hbase.tool.DataBlockEncodingValidator
-
- addOptions() - Method in class org.apache.hadoop.hbase.tool.HFileContentValidator
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- addOptNoArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptNoArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOverlap(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- addParam(QueryStringEncoder, String, Object) - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
Adds value
to encoder
under paramName
when value
is non-null.
- addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- addPeer(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandler
-
- addPeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- addPeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
1.
- addPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Method called after a peer has been connected.
- addPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Add a replication peer.
- addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- AddPeerProcedure - Class in org.apache.hadoop.hbase.master.replication
-
The procedure for adding a new replication peer.
- AddPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- AddPeerProcedure(String, ReplicationPeerConfig, boolean) - Constructor for class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- addPeerToHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- addPeerToHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Add a peer to hfile reference queue if peer does not exist.
- addPeerToHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- addPrimaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Adds a servlet in the server that only administrators can access.
- addPrivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Adds a servlet in the server that only administrators can access.
- addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Adds a servlet in the server that any user can access.
- addProperty(String, String) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
Add property to the namespace.
- addProviderIfNotExists(SaslClientAuthenticationProvider, HashMap<Byte, SaslClientAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Adds the given provider
to the set, only if an equivalent provider does not already
exist in the set.
- addProviderIfNotExists(SaslServerAuthenticationProvider, HashMap<Byte, SaslServerAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Adds the given provider into the map of providers if a mapping for the auth code does not
already exist in the map.
- addPushSize(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Add current size to the current cycle's total push size
- addPutToKv(Put, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- addQuotas(Connection, byte[], QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addQuotas(Connection, byte[], byte[], QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addr - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- addr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
-
- addr - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- addr2Stub - Variable in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- addReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- addRecord(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
Add various NamedQueue records to ringbuffer.
- addReferenceFiles(SnapshotManifest.RegionVisitor, Object, Object, Collection<StoreFileInfo>, boolean) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- addRegion(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- addRegion(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- addRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- addRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addRegion(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
-
Add to online regions.
- addRegion(byte[], int, int, int, int, long, long, long, int, int, int, long, long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Add a region name to the list
- addRegion(LinkedList<RegionInfo>, RegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- addRegion(HRegion) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
- addRegion(HRegion, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- addRegion(Path, RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Creates a 'manifest' for the specified region, by reading directly from the disk.
- addRegion(Path, RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- addRegionInfo(Put, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addRegionInfo(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- addRegionPlan(MinMaxPriorityQueue<RegionPlan>, boolean, ServerName, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
Add a region from the head or tail to the List of regions to return.
- addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServerQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addRegionSize(RegionInfo, long, long) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- addRegionSorted(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- addRegionStateToPut(Put, RegionState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addRegionsToInMemoryStates(List<RegionInfo>, MasterProcedureEnv, int) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Add regions to in-memory states
- addRegionsToMeta(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Add regions to hbase:meta table.
- addRegionsToMeta(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
Add the specified set of regions to the hbase:meta table.
- addRegionsToMeta(Connection, List<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- addRegionsToMeta(Connection, List<RegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- addRegionToMap(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- addRegionToMap(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- addRegionToMeta(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a (single) hbase:meta row for the specified new region and its daughters.
- addRegionToRemove(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- addRegionToRestore(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- addRegionToServer(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- addRegionToSnapshot(SnapshotProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Complete taking the snapshot on the region.
- addReplicaActions(int, Map<ServerName, MultiAction>, List<Action>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
Add replica actions to action map by server.
- addReplicaActionsAgain(Action, Map<ServerName, MultiAction>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
- addReplicas(List<RegionInfo>, int, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
- addReplicationBarrier(Put, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
See class comment on SerialReplicationChecker
- addReplicationParent(Put, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer for replicating data to slave cluster.
- addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Add a new replication peer for replicating data to slave cluster
- addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a new replication peer but does not block and wait for it.
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- addRequiredOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addRequiredOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addRequiredOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addResource(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- addResource(URL) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- addResource(Path) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- addResource(InputStream) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- addResource(InputStream, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- addResource(Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- address - Variable in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- address - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- Address - Class in org.apache.hadoop.hbase.net
-
An immutable type to hold a hostname and port combo, like an Endpoint or
java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve
happening every time we want to hold a hostname and port combo).
- Address(HostAndPort) - Constructor for class org.apache.hadoop.hbase.net.Address
-
- address - Variable in class org.apache.hadoop.hbase.ServerName
-
- ADDRESS_BITS_PER_WORD - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- addresses - Variable in class org.apache.hadoop.hbase.client.BatchErrors
-
- Addressing - Class in org.apache.hadoop.hbase.util
-
Utility for network addresses, resolving and naming.
- Addressing() - Constructor for class org.apache.hadoop.hbase.util.Addressing
-
- Addressing.AddressSelectionCondition - Interface in org.apache.hadoop.hbase.util
-
Interface for AddressSelectionCondition to check if address is acceptable
- addressIsLocalHost(String) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
- addResult(int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- addResult(ClientProtos.MutateResponse.Builder, Result, HBaseRpcController, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- addResults(ClientProtos.ScanResponse.Builder, List<Result>, HBaseRpcController, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- addRollbackStep(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
Called by the ProcedureExecutor after the procedure step is completed, to add the step to the
rollback list (or procedure stack)
- addRow(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Add a row to this cell set
- ADDRS_CONF_SEPARATOR - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- addRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Creates a new RegionServer group with the given name.
- addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- addRSGroup(RpcController, RSGroupAdminProtos.AddRSGroupRequest, RpcCallback<RSGroupAdminProtos.AddRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- addRSGroup(RSGroupInfo) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Add given RSGroupInfo to existing list of group infos.
- addRSGroup(RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- addScanner(String, RegionScanner, Shipper, HRegion, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- addScanner(RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
-
- addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Assigns a unique ID to the scanner and adds the mapping to an internal hash-map.
- addScanner(ResultScanner) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
Assigns a unique ID to the scanner and adds the mapping to an internal HashMap.
- addScannerLeaseBack(LeaseManager.Lease) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- addScanResult(List<Result>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a scan result.
- addSecondaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- addSecurityHeadersFilter(ServletContextHandler, Configuration, boolean) - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- addSequenceNum(Put, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Adds the given server to the group.
- addServer(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Add the server to the drain list.
- addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- addServletWithAuth(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Internal method to add a servlet to the HTTP server.
- addServletWithAuth(String, ServletHolder, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Internal method to add a servlet to the HTTP server.
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV1
-
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV2
-
- addSize(RpcCallContext, Result, Object) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Method to account for the size of retained cells and retained data blocks.
- addSkippedRegion(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- addSlowAckData(DatanodeInfo, long, long) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- addSlowLogRecords(List<TooSlowLog.SlowLogPayload>, Configuration) - Static method in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
Add slow/large log records to hbase:slowlog table
- addSnapshot(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot
- addSnapshotClone(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot cloned table
- addSnapshotRestore(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot
- addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Add a normal source for the given peer on this region server.
- addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- addSplitsToParent(Connection, RegionInfo, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds daughter region infos to hbase:meta row for the specified region.
- addStackIndex(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the RootProcedureState on procedure execution.
- addStatistic(byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- addStoreFile(RegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile, Map<Path, Integer>) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Add the specified store file to the stats
- addStoreFiles(Collection<HStoreFile>, StoreEngine.IOExceptionRunnable) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Add the store files to store file manager, and also record it in the store file tracker.
- addStringMap(Map<String, String>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add String map to config list.
- addSublist(List<T>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- addSubProcedure(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- addSystemLabel(Region, Map<String, Integer>, Map<String, List<Integer>>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Add the named table to be those being archived.
- addTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- addTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
- addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- addTableAcl(TableName, Set<String>, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Add table user acls
- addTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Add the table descriptor to the snapshot manifest
- addTableQuota(Connection, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addTableQuotaTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Adds a table with a table quota.
- addTableToMeta(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- addTarget(RegionInfo, long) - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan.Builder
-
- addTeritiaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- addTimer(String, Timer, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
- addToCache(AsyncNonMetaRegionLocator.TableCache, RegionLocations) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- addToCache(Result) - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- addToCachedServers(RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
- addToCompactingFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds the files to compacting files.
- addToCompactionQueue(ServerName, MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- addToCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
nn
- addToFailedOpen(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- addToFailedServers(Address, Throwable) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
-
Add an address to the list of the failed servers list.
- addToHashMultiMap(Map<K1, Map<K2, List<V>>>, K1, K2, V) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Simple helper to a map from key to (a list of) values TODO: Make a general utility method nnnn
* @return the list of values corresponding to key1 and key2
- addToHDFSBlocksDistribution(HDFSBlocksDistribution, BlockLocation[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Update blocksDistribution with blockLocations
- addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
-
Adds the given Token to the user's credentials.
- addTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary, and
adds it to the credentials for the given map reduce job.
- addTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary, and
adds it to the credentials for the given map reduce job.
- addTokenIfMissing(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks if an authentication tokens exists for the connected cluster, obtaining one if needed
and adding it to the user's credentials.
- addToList(List<String>, String, ReplicationQueueStorage) - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- addToLockedResources(List<LockedResource>, Map<T, LockAndQueue>, Function<T, String>, LockedResourceType) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- addToMap(Map<String, Long>, String, long, ReplicationQueueStorage) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- addToMovedRegions(String, ServerName, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToOfflineRegions(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- addToPendingAssignment(HashMap<RegionInfo, RegionStateNode>, Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- addToQueueForSysTable(TooSlowLog.SlowLogPayload) - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
- addToReplicaLoad(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- addToRollingStats(HeapMemoryManager.TunerContext) - Method in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
Add the given context to the rolling tuner stats.
- addToRunQueue(FairQueue<T>, Queue<T>, Supplier<String>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- addToScanners(List<? extends Segment>, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- addToScanners(Segment, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- addToSize(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
Used to update in-progress log sizes.
- addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Add a type to the filter list
- addUniqueWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to the total unique weight
- addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Adds a servlet in the server that any user can access.
- addUnprivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Adds a servlet in the server that any user can access.
- addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Adds a servlet in the server that any user can access.
- addUnprivilegedServlet(String, String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Adds a servlet in the server that any user can access.
- addUsedSplitWALWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
When master restart, there will be a new splitWorkerAssigner.
- addUsedWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- addUserEntry(Table, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addUserGlobalHdfsAcl(Table, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addUserNamespaceHdfsAcl(Table, String, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addUserPermission(Configuration, UserPermission, Table, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Stores a new user permission grant in the access control lists table.
- addUserPermission(Configuration, UserPermission, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- addUserQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addUserQuota(Connection, String, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addUserTableHdfsAcl(Connection, Set<String>, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addUserTableHdfsAcl(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addUserTableHdfsAcl(Table, String, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- addVersionDelete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
-
- addVersionDelete(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode
-
- addWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- addWAL(ServerName, String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Add a new WAL file to the given queue for a given regionserver.
- addWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- addWAL(WAL) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- addWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
- addWeight(long, long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
add weight
- addWorkerStuckPercentage - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- addWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- adjustFieldLength - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- adjustFieldLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- adjustFieldLengthIfNeeded() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- Admin - Interface in org.apache.hadoop.hbase.client
-
The administrative API for HBase.
- admin - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- admin - Variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- admin - Variable in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- admin - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- admin - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- admin - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- admin - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- admin - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- admin - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- admin - Variable in class org.apache.hadoop.hbase.util.ConnectionCache.ConnectionInfo
-
- admin - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- admin - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
-
- admin - Variable in class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- admin - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- AdminAuthorizedFilter - Class in org.apache.hadoop.hbase.http
-
- AdminAuthorizedFilter() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
-
- AdminAuthorizedServlet - Class in org.apache.hadoop.hbase.http
-
General servlet which is admin-authorized.
- AdminAuthorizedServlet() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
-
- adminCall(HBaseRpcController, AdminProtos.AdminService.Interface, PREQ, RawAsyncHBaseAdmin.AdminRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<RESP, PRESP>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- adminRequest() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- AdminRequestCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- ADMINS_ACL - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- adminsAcl - Variable in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
-
- adminsAcl - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- adminsAcl - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- adminSubs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- adoptHdfsOrphan(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Orphaned regions are regions without a .regioninfo file in them.
- adoptHdfsOrphans(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Iterates through the list of all orphan/invalid regiondirs.
- advance() - Method in interface org.apache.hadoop.hbase.CellScanner
-
Advance the scanner 1 cell.
- advance() - Method in class org.apache.hadoop.hbase.client.Result
-
- advance() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- advance() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
-
- AdvancedScanResultConsumer - Interface in org.apache.hadoop.hbase.client
-
This is the low level API for asynchronous scan.
- AdvancedScanResultConsumer.ScanController - Interface in org.apache.hadoop.hbase.client
-
Used to suspend or stop a scan, or get a scan cursor if available.
- AdvancedScanResultConsumer.ScanResumer - Interface in org.apache.hadoop.hbase.client
-
Used to resume a scan.
- advanceTick() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- advanceTo(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Step the MVCC forward on to a new read/write basis.
- AES - Class in org.apache.hadoop.hbase.io.crypto.aes
-
AES-128, provided by the JCE
- AES(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- AESDecryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- AESDecryptor(Cipher) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- AESEncryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- AESEncryptor(Cipher, SecureRandom) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Used to manufacture race condition reliably.
- afterDecodingKeyValue(DataInputStream, ByteBuffer, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- afterEncodingKeyValue(Cell, DataOutputStream, HFileBlockDefaultEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
Returns unencoded size added
- afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.TrackingThreadPoolExecutor
-
- afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
-
- afterExecution(Store) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker
-
Called after compaction is executed by CompactSplitThread.
- afterExecution() - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
-
Called after flush is executed.
- afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- afterReplay(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called when the procedure is ready to be added to the queue after the loading/replay operation.
- afterWALArchive(Path, Path) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- afterWALArchive(Path, Path) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- ageAtEviction - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
Keep running age at eviction time
- ageHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- ageHistogram - Variable in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- agentName - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- ageOfLastAppliedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- ageOfLastAppliedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- ageOfLastShippedOpKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- ageOfLastShippedOpKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
-
Snapshot of block cache age in cache.
- AgeSnapshot(FastLongHistogram) - Constructor for class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- agg - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- agg - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- aggLock - Variable in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
-
- aggregateRecords(List<Record>, Field) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
-
- aggregateRecordsAndAddDistinct(List<Record>, Field, Field, Field) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
Aggregate the records and count the unique values for the given distinctField
- aggregateRequestPerSecond - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- AggregatingCompleteTracker(CompactionLifeCycleTracker, int) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit.AggregatingCompleteTracker
-
- aggregationWindow - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- alarming - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTunerChore
-
- Algorithm(String, String, String) - Constructor for enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- algorithm - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Use
MessageDigest
class's encryption algorithms to check persistent file
integrity, default algorithm is MD5
- algorithm - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- align(long) - Method in class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
-
Aligns a number to 8.
- alignDown(long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Returns lower boundary (aligned to multiple of BITS_PER_WORD) of bitmap range x belongs to.
- alignUp(long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Returns upper boundary (aligned to multiple of BITS_PER_WORD) of bitmap range x belongs to.
- ALL_FLAG_BITS - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- ALL_TIME - Static variable in class org.apache.hadoop.hbase.io.TimeRange
-
- ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Define for 'return-all-versions'.
- allBufs - Variable in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- allCells - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- allChannels - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- allChannels - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- allCompactedFilesCached - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
-
- allFilesCached - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
-
Cached list of all files in the structure, to return from some calls
- allFilesExpired(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- allKeys - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- allL0FilesExpired(StripeCompactionPolicy.StripeInformationProvider) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- alloc - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- ALLOC - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- alloc - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufOutputStreamSupplier
-
- alloc(int) - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
Try to allocate size
bytes from the chunk.
- allocate(int) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Allocate size bytes from the ByteBufAllocator, Note to call the
ByteBuff.release()
if
no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.
- allocate(int, boolean) - Static method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- allocate() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
Allocate a block in this bucket, return the offset representing the position in physical
space
- allocate(int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- allocate(long) - Method in interface org.apache.hadoop.hbase.util.ByteBufferAllocator
-
Allocates a bytebuffer
- allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Allocate a block with specified size.
- allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
Find a bucket to allocate a block
- allocateBuffer(ChannelHandlerContext, ByteBuf, boolean) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.EncryptHandler
-
- allocateBufferForUnpacking() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Always allocates a new buffer of the correct size.
- allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.OffheapChunk
-
- allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.OnheapChunk
-
- allocateNewBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- allocateNewChunk() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- allocateOneBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Allocate an buffer with buffer size from ByteBuffAllocator, Note to call the
ByteBuff.release()
if no need any more, otherwise the memory leak happen in NIO
ByteBuffer pool.
- allocateOnHeap(int) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- ALLOCATION_FAIL_LOG_TIME_PERIOD - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- allocationFailCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- allocationFailed() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- allocator - Variable in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- allocator - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
-
- allocator - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- ALLOCATOR_FOR_TEST - Static variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- ALLOCATOR_POOL_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- allocBloom() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- allocCount - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
Total number of allocations satisfied from this buffer
- allocFailLogPrevTs - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- allocIndexChunks(int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- allOf(List<CompletableFuture<T>>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
Returns a new CompletableFuture that is completed when all of the given CompletableFutures
complete.
- allow(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allowableError(int) - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Specifies the allowable error for this rank, depending on which quantiles are being targeted.
- allowCompaction - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- allowCoreThreadTimeout - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- allowCoreThreadTimeout() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- allowed - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
-
- ALLOWED_METHODS - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- allowedFailures - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- allowFallbackToSimpleAuth - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- allowPartialResults - Variable in class org.apache.hadoop.hbase.client.Scan
-
- AllowPartialScanResultCache - Class in org.apache.hadoop.hbase.client
-
A ScanResultCache that may return partial result.
- AllowPartialScanResultCache() - Constructor for class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
-
- allRegions - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- allRequests - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- allTime - Variable in class org.apache.hadoop.hbase.io.TimeRange
-
- allTime() - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- alpha - Variable in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
-
- ALPHA_NUMERIC - Static variable in class org.apache.hadoop.hbase.http.ProfileOutputServlet
-
- alreadyRunning - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- alt - Variable in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- alternateBufferedMutatorClassName - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Allow setting an alternate BufferedMutator implementation via config.
- ALWAYS_COPY_FILES - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- ALWAYS_COPY_FILES - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- amd64 - Static variable in class org.apache.hadoop.hbase.util.JVM
-
- ampBytes - Static variable in class org.apache.hadoop.hbase.http.HtmlQuoting
-
- AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Byte Array
- AND - Static variable in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Array
- AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- AND_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- annotateBytesRead(AttributesBuilder, long, long) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Conditionally annotate attributesBuilder
with appropriate attributes when values are
non-zero.
- annotatedQos - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- annotateHeapBytesRead(AttributesBuilder, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Conditionally annotate span
with the appropriate attribute when value is non-zero.
- AnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.regionserver
-
Reads special method annotations and table names to figure a priority for use by QoS facility in
ipc; e.g: rpcs to hbase:meta get priority.
- AnnotationReadingPriorityFunction(RSRpcServices) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- AnnotationReadingPriorityFunction(RSRpcServices, Class<? extends RSRpcServices>) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
Constructs the priority function given the RPC server implementation and the annotations on the
methods in the provided clz
.
- ap - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- ap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- aposBytes - Static variable in class org.apache.hadoop.hbase.http.HtmlQuoting
-
- APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- Append - Class in org.apache.hadoop.hbase.client
-
Performs Append operations on a single row.
- Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Copy constructor
- Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- Append(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Construct the Append with user defined data.
- append(Append) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Appends values to one or more columns within a single row.
- append(Append) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
-
- append(Append) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
-
Appends values to one or more columns within a single row.
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- append(StringBuilder, String) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Append the given key/value pair to the file info, optionally checking the key prefix.
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Add key/value to file.
- append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.CellSink
-
Append the given cell
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
-
- append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more append operations on a row.
- append(HRegion, OperationQuota, ClientProtos.MutationProto, CellScanner, long, ActivePolicyEnforcement) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Execute an append mutation.
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Append a set of edits to the WAL.
- append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- append(FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
Append to the WAL.
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- append(TableName, byte[], byte[], List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- append(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
Validates the input request parameters, parses columns from CellSetModel, and invokes Append on
HTable.
- append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- append(Append) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- append(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Append a node to the tree
- append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
-
- append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- APPEND_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- APPEND_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- appendAndSync() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- appendCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Append a set of data edits to the WAL.
- appendDeleteFamilyBloomFilter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- appendEntry(W, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers
-
Append a log entry into the corresponding region buffer.
- appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- appendExcludeTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- appendFileInfo(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Add an element to the file info map.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Add to the file info.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- appendFromHBase(Append) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
From a
TAppend
create an
Append
.
- appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- appendGeneralBloomfilter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- appendHFileRefsZNodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
- appendHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- appendHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- appendJRuby(StringBuilder, Object) - Static method in class org.apache.hadoop.hbase.util.JRubyFormat
-
- appendKeyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- appendKeyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendList(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Append a list of nodes to the tree
- appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Append an operational 'meta' event marker edit to the WAL.
- appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Add a meta block to the end of the file.
- appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Writes meta data.
- appendMetadata(long, boolean, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Writes meta data.
- appendMetadata(long, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Writes meta data.
- appendMetaData(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- appendMobMetadata(SetMultimap<TableName, String>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Appends MOB - specific metadata (even if it is empty)
- appendPeerState(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
- appendPeersZnodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
- appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Append the replicable table column family config from the specified peer.
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Append the replicable table-cf config of the specified peer
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- appendRSZnodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
- appendSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- appendStrings(StringBuilder, String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- appendTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
Print all of the thread's information and stack traces.
- appendTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- appendTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- appendTo(Cell, ByteBuffer, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Copy the Cell content into the passed buf in KeyValue serialization format.
- appendToByteArray(Cell, byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
copy key and value
- appendToByteBuffer(ByteBuffer, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Add TimestampRange and earliest put timestamp to Metadata
- appendTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- apply(FileStatus) - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileStatusConverter
-
- apply(HStoreFile) - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.StoreToFile
-
- apply(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetPathName
-
- apply(FileSystem, Path, List<AclEntry>) - Method in interface org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.Operation
-
- apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte val
.
- apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte array val
.
- apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to a range within the byte array val
.
- applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetBulkTime
-
- applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetFileSize
-
- applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetMaxTimestamp
-
- applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Convience method to change metrics when a batch of operations are applied.
- applyBatch(long, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Convience method to change metrics when a batch of operations are applied.
- applyClusterKeyToConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Apply the settings in the given key to the given configuration, this is used to communicate
with distant clusters
- applyCompactionPolicy(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
- applyCompactionPolicy(List<HStoreFile>, boolean, boolean, int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
- applyCompactionPolicy(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
-- Default minor compaction selection algorithm: choose CompactSelection from candidates --
First exclude bulk-load files if indicated in configuration.
- applyCostsChange(Consumer<double[]>) - Method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
We do not want to introduce a getCosts method to let upper layer get the cost array directly,
so here we introduce this method to take a
Consumer
as parameter, where we will pass
the actual cost array in, so you can change the element of the cost array in the
Consumer
implementation.
- applyFamilyMapToMemStore(Map<byte[], List<Cell>>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
Atomically apply the given map of family->edits to the memstore.
- applyFilterAndGet(List<Record>, List<RecordFilter>) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
-
Filter records as per the supplied filters,
- applyToMemStore(HStore, List<Cell>, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- applyToMemStore(HStore, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- archive(FileSystem, RegionInfo, byte[], Collection<HStoreFile>, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
- archive(String) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
Archive processed WAL
- archive - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- archive(Pair<Path, Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- archive(Path, boolean, Path, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Moves processed logs to a oldLogDir after successful processing Moves corrupted logs (any log
that couldn't be successfully parsed to corruptDir (.corrupt) for later investigation
- ARCHIVED_HFILE_SUFFIX - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- ARCHIVED_WAL_SUFFIX - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- archiveDataDir - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- archivedHFileSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- archivedHFileSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedHFileSuffix(String) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedHFileSuffix() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedTables - Variable in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- archivedWalSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedWalSuffix(String) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedWalSuffix() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- archivedWALSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- archiveExecutor - Static variable in class org.apache.hadoop.hbase.backup.HFileArchiver
-
- archiveFamily(FileSystem, Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove from the specified region the store files of the specified column family, either by
archiving them or outright deletion
- archiveFamilyByFamilyDir(FileSystem, Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Removes from the specified region the store files of the specified column family, either by
archiving them or outright deletion
- archiveHFileZNode - Variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- archiveLock - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
Lock specific to archiving compacted store files.
- archiveLogFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- archiveMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
The hbase:meta region may OPEN and CLOSE without issue on a server and then move elsewhere.
- archiveMobFiles(Configuration, TableName, byte[], List<Path>) - Method in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
Archives the mob files.
- archiveMobFiles(Configuration, TableName, byte[], List<Path>) - Method in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
-
Archives the mob files.
- archivePath - Variable in class org.apache.hadoop.hbase.io.HFileLink
-
- archiveRecoveredEdits(Configuration, FileSystem, RegionInfo, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive recovered edits using existing logic for archiving store files.
- archiveRecoveredEdits(String, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem
-
Closes and archives the specified store files from the specified family.
- archiveRegion(Configuration, FileSystem, RegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
- archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove an entire region from the table directory via archiving the region's hfiles.
- archiveRegions(Configuration, FileSystem, Path, Path, List<Path>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive the specified regions in parallel.
- archiveRetries - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- archiveStoreFile(Configuration, FileSystem, RegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive the store file
- archiveStoreFiles(Configuration, FileSystem, RegionInfo, Path, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove the store files, either by archiving them or outright deletion
- archiveTracker - Variable in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- archiveZnode - Variable in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
-
- areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Check whether two regions are adjacent; i.e.
- areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- areAllLower(Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
See if passed sequenceids
are lower -- i.e.
- areAllUserRegionsOffline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
-
- areCompactionsDisabled(TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns whether or not compactions should be disabled for the given tableName
per
a space quota violation policy.
- areCompactionsDisabled() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Returns whether or not compactions on this table should be disabled for this policy.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Checks if there are currently any dead servers being processed by the master.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Checks if any dead servers are currently in progress.
- arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Check whether two parts in the same buffer are equal.
- areScanStartRowAndStopRowEqual(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
-
- areSerializedFieldsEqual(BigDecimalComparator) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Return true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Concrete implementers can signal a failure condition in their code by throwing an
IOException
.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Default implementation so that writers of custom filters aren't forced to implement.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
Deprecated.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(LongComparator) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
Returns true if and only if the fields of the comparator that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
Returns true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
Return true if and only if the fields of the filter that are serialized are equal to the
corresponding fields in other.
- areSomeRegionReplicasColocated(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- areSplittersAvailable() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Returns true if more splitters are available, otherwise false.
- areSyncFuturesReleased() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
- areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- areWritesEnabled() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- args - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
-
- argumentToClassMap - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- array() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the byte[] if the underlying BB has single BB and hasArray true
- array() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- array() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Array overhead
- ARRAY_BYTE_INDEX_SCALE - Static variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
-
- ARRAY_CACHE - Static variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- ARRAY_CACHE - Static variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- ARRAY_OBJECT_INDEX_SCALE - Static variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
-
- ArrayBackedTag - Class in org.apache.hadoop.hbase
-
This is a
Tag
implementation in which value is backed by an on heap byte array.
- ArrayBackedTag(byte, String) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
-
The special tag will write the length of each tag and that will be followed by the type and
then the actual tag.
- ArrayBackedTag(byte, byte[]) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
-
Format for a tag : <length of tag - 2 bytes><type code - 1 byte><tag>
tag length is
serialized using 2 bytes only but as this will be unsigned, we can have max tag length of
(Short.MAX_SIZE * 2) +1.
- ArrayBackedTag(byte[], int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
-
Creates a Tag from the specified byte array and offset.
- ArrayBackedTag(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
-
Creates a Tag from the specified byte array, starting at offset, and for length
length
.
- ArrayEntryIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntryIterator
-
- ArrayEntrySet(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- arrayHeaderSize() - Method in class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
-
- arrayHeaderSize() - Method in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
-
- ArrayHolder(Comparator<? super K>, Comparator<Map.Entry<K, V>>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- ArrayHolder(CopyOnWriteArrayMap.COWEntry[], int, int, Comparator<? super K>, Comparator<Map.Entry<K, V>>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- ArrayKeyIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeyIterator
-
- ArrayKeySet(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ArrayList(0)
- arrayOffset() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the arrayOffset of the byte[] incase of a single BB backed ByteBuff
- arrayOffset() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- arrayOffset() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- ArrayValueCollection(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- ArrayValueIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueIterator
-
- arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- ascendingSort - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- asFloat() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- asInt() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- asInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
Returns an InterruptedIOException if t was an interruption, null otherwise
- asList(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Creates list of tags from given byte array, expected that it is in the expected tag format.
- asLong() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
The block cached in LruAdaptiveBlockCache will always be an heap block: on the one side, the
heap access will be more faster then off-heap, the small index block or meta block cached in
CombinedBlockCache will benefit a lot.
- asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
The block cached in LRUBlockCache will always be an heap block: on the one side, the heap
access will be more faster then off-heap, the small index block or meta block cached in
CombinedBlockCache will benefit a lot.
- asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
The block cached in TinyLfuBlockCache will always be an heap block: on the one side, the heap
access will be more faster then off-heap, the small index block or meta block cached in
CombinedBlockCache will benefit a lot.
- asSeparateLines(String) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
Format a string of the form "k1=v1, k2=v2, ..." into separate lines with a four-space
indentation.
- assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This throws a WrongRegionException if the HFile does not fit in this region, or an
InvalidHFileException if the HFile is not valid.
- assertCounterSanity(long, long) - Static method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Sanity-checking for parity between actual block cache content and metrics.
- assertCounterSanity(long, long) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Sanity-checking for parity between actual block cache content and metrics.
- assertMapEmpty() - Method in class org.apache.hadoop.hbase.util.IdLock
-
- assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- assertSnapshotRequestIsValid(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Check to make sure that the description of the snapshot requested is valid
- assertSplitResultFilesCount(FileSystem, int, Path) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- assertValidSeek() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Assign a Region.
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Assign an individual region.
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- assign(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assign(MasterProcedureEnv, RegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- assign(MasterProcedureEnv, RegionInfo, boolean, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- assign(Collection<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- assign(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ASSIGN_DISPATCH_WAIT_MSEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- ASSIGN_DISPATCH_WAITQ_MAX_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- ASSIGN_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- ASSIGN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- ASSIGN_RETRY_IMMEDIATELY_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- ASSIGN_SEQ_IDS - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- ASSIGN_SEQ_IDS - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- assignAsync(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Submits a procedure that assigns a region to a target server without waiting for it to finish
- assignAsync(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Submits a procedure that assigns a region without waiting for it to finish
- assignCandidate - Variable in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- assignCandidate - Variable in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- assignDispatchWaitMillis - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignDispatchWaitQueueMaxSize - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignMasterSystemRegions(Collection<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- assignMaxAttempts - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- AssignmentManager - Class in org.apache.hadoop.hbase.master.assignment
-
The AssignmentManager is the coordinator for region assign/unassign operations.
- AssignmentManager(MasterServices, MasterRegion) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- AssignmentManager(MasterServices, MasterRegion, RegionStateStore) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignmentManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- AssignmentManager.DeadServerMetricRegionChore - Class in org.apache.hadoop.hbase.master.assignment
-
- AssignmentManager.RegionInTransitionChore - Class in org.apache.hadoop.hbase.master.assignment
-
- AssignmentManager.RegionInTransitionStat - Class in org.apache.hadoop.hbase.master.assignment
-
- AssignmentManager.RegionMetaLoadingVisitor - Class in org.apache.hadoop.hbase.master.assignment
-
- assignmentManagerSource - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- AssignmentManagerUtil - Class in org.apache.hadoop.hbase.master.assignment
-
Utility for this assignment package only.
- AssignmentManagerUtil() - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- AssignmentProcedureEvent(RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStateNode.AssignmentProcedureEvent
-
- assignments - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- AssignmentVerificationReport - Class in org.apache.hadoop.hbase.master
-
- AssignmentVerificationReport() - Constructor for class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- assignMetaReplica(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- assignMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- assignNewReplicasIfNeeded(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- AssignProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
- AssignProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- assignProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- assignQueueFullCond - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignQueueLock - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignQueueSignal() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- AssignRegionAction - Class in org.apache.hadoop.hbase.master.balancer
-
- AssignRegionAction(int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
-
- AssignRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles opening of a region on a region server.
- AssignRegionHandler(HRegionServer, RegionInfo, long, TableDescriptor, long, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- assignRegions(MasterProcedureEnv, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Assign the regions on the crashed RS to other Rses.
- assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- assignRetryImmediatelyMaxAttempts - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- assigns(List<String>, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- assigns(List<String>, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Like
Admin.assign(byte[])
but 'raw' in that it can do more than one Region at a time --
good if many Regions to online -- and it will schedule the assigns even in the case where
Master is initializing (as long as the ProcedureExecutor is up).
- assigns(List<String>) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
- assigns(RpcController, MasterProtos.AssignsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
A 'raw' version of assign that does bulk and can skirt Master state checks if override is set;
i.e.
- assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper, List<RegionInfo>, Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- assignSeqIds - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- assignTableToGroup(TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- assignThread - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- asSize() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- asString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns bytes from current position till length specified, as a single ByteBuffer.
- asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns bytes from given offset till length specified, as a single ByteBuffer.
- asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns bytes from current position till length specified, as a single ByteBuffer.
- asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns bytes from given offset till length specified, as a single ByteBuffer.
- asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- asSubByteBuffers(long, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Creates a sub-array from a given array of ByteBuffers from the given offset to the length
specified.
- ASTERICK - Static variable in class org.apache.hadoop.hbase.util.JSONBean
-
- ASYNC_DFS_OUTPUT_CREATE_MAX_RETRIES - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- ASYNC_PROFILER_HOME_ENV - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- ASYNC_PROFILER_HOME_SYSTEM_PROPERTY - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- ASYNC_WAL_USE_SHARED_EVENT_LOOP - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- ASYNC_WAL_WAIT_ON_SHUTDOWN_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- AsyncAdmin - Interface in org.apache.hadoop.hbase.client
-
The asynchronous administrative API for HBase.
- asyncAdmin - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- AsyncAdminBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncAdminBuilderBase - Class in org.apache.hadoop.hbase.client
-
Base class for all asynchronous admin builders.
- AsyncAdminBuilderBase(AsyncConnectionConfiguration) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- AsyncAdminRequestRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncAdminRequestRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, ServerName, AsyncAdminRequestRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
-
- AsyncAdminRequestRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
-
- AsyncBatchRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
Retry caller for batch.
- AsyncBatchRpcRetryingCaller(Timer, AsyncConnectionImpl, TableName, List<? extends Row>, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- AsyncBatchRpcRetryingCaller.RegionRequest - Class in org.apache.hadoop.hbase.client
-
- AsyncBatchRpcRetryingCaller.ServerRequest - Class in org.apache.hadoop.hbase.client
-
- AsyncBufferedMutator - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table in batches.
- AsyncBufferedMutatorBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncBufferedMutatorBuilderImpl - Class in org.apache.hadoop.hbase.client
-
- AsyncBufferedMutatorBuilderImpl(AsyncConnectionConfiguration, AsyncTableBuilder<?>, HashedWheelTimer) - Constructor for class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- AsyncBufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
-
- AsyncBufferedMutatorImpl(HashedWheelTimer, AsyncTable<?>, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- AsyncClientExample - Class in org.apache.hadoop.hbase.client.example
-
A simple example shows how to use asynchronous client.
- AsyncClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- AsyncClientScanner - Class in org.apache.hadoop.hbase.client
-
The asynchronous client scanner implementation.
- AsyncClientScanner(Scan, AdvancedScanResultConsumer, TableName, AsyncConnectionImpl, Timer, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- AsyncClientScanner.OpenScannerResponse - Class in org.apache.hadoop.hbase.client
-
- AsyncConnection - Interface in org.apache.hadoop.hbase.client
-
The asynchronous version of Connection.
- AsyncConnectionConfiguration - Class in org.apache.hadoop.hbase.client
-
Timeout configs.
- AsyncConnectionConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- AsyncConnectionImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of AsyncConnection.
- AsyncConnectionImpl(Configuration, ConnectionRegistry, String, User) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- asyncCreate(ZKWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Async creates the specified node with the specified data.
- asyncDecode(CachedData) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache.HFileBlockTranscoder
-
- AsyncFSOutput - Interface in org.apache.hadoop.hbase.io.asyncfs
-
Interface for asynchronous filesystem output stream.
- AsyncFSOutputHelper - Class in org.apache.hadoop.hbase.io.asyncfs
-
Helper class for creating AsyncFSOutput.
- AsyncFSOutputHelper() - Constructor for class org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper
-
- AsyncFSWAL - Class in org.apache.hadoop.hbase.regionserver.wal
-
An asynchronous implementation of FSWAL.
- AsyncFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- AsyncFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- AsyncFSWALProvider - Class in org.apache.hadoop.hbase.wal
-
- AsyncFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
- AsyncFSWALProvider.AsyncWriter - Interface in org.apache.hadoop.hbase.wal
-
- asyncGetBlockDistribution(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- AsyncHBaseAdmin - Class in org.apache.hadoop.hbase.client
-
- AsyncHBaseAdmin(RawAsyncHBaseAdmin, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- AsyncMasterRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
Retry caller for a request call to master.
- AsyncMasterRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, AsyncMasterRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
-
- AsyncMasterRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
-
- AsyncMetaRegionLocator - Class in org.apache.hadoop.hbase.client
-
The asynchronous locator for meta region.
- AsyncMetaRegionLocator(ConnectionRegistry) - Constructor for class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- AsyncMetaTableAccessor - Class in org.apache.hadoop.hbase
-
The asynchronous meta table accessor.
- AsyncMetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- AsyncMetaTableAccessor.MetaTableScanResultConsumer - Class in org.apache.hadoop.hbase
-
- AsyncNonMetaRegionLocator - Class in org.apache.hadoop.hbase.client
-
The asynchronous locator for regions other than meta.
- AsyncNonMetaRegionLocator(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- AsyncNonMetaRegionLocator.LocateRequest - Class in org.apache.hadoop.hbase.client
-
- AsyncNonMetaRegionLocator.RegionLocationsFutureResult - Class in org.apache.hadoop.hbase.client
-
- AsyncNonMetaRegionLocator.TableCache - Class in org.apache.hadoop.hbase.client
-
- asyncOutputWrapper - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- asyncPrefetch - Variable in class org.apache.hadoop.hbase.client.Scan
-
- AsyncProcess - Class in org.apache.hadoop.hbase.client
-
This class allows a continuous flow of requests.
- AsyncProcess(ClusterConnection, Configuration, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcess
-
- AsyncProcess(ClusterConnection, Configuration, RpcRetryingCallerFactory, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcess
-
- asyncProcess - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- asyncProcess - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- asyncProcessNodeUpdate(Runnable) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- AsyncProcessTask<T> - Class in org.apache.hadoop.hbase.client
-
Contains the attributes of a task which will be executed by
AsyncProcess
.
- AsyncProcessTask(AsyncProcessTask<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- AsyncProcessTask(ExecutorService, TableName, RowAccess<? extends Row>, AsyncProcessTask.SubmittedRows, Batch.Callback<T>, CancellableRegionServerCallable, boolean, int, int, Object[]) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- AsyncProcessTask.Builder<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncProcessTask.ListRowAccess<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncProcessTask.SubmittedRows - Enum in org.apache.hadoop.hbase.client
-
The number of processed rows.
- asyncProfilerHome - Variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- AsyncProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
AsyncWriter for protobuf-based WAL.
- AsyncProtobufLogWriter(EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- AsyncProtobufLogWriter.OutputStreamWrapper - Class in org.apache.hadoop.hbase.regionserver.wal
-
- AsyncRegionLocator - Class in org.apache.hadoop.hbase.client
-
The asynchronous region locator.
- AsyncRegionLocator(AsyncConnectionImpl, HashedWheelTimer) - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- AsyncRegionLocatorHelper - Class in org.apache.hadoop.hbase.client
-
Helper class for asynchronous region locator.
- AsyncRegionLocatorHelper() - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
- AsyncRequestFuture - Interface in org.apache.hadoop.hbase.client
-
The context used to wait for results from one submit call.
- AsyncRequestFutureImpl<CResult> - Class in org.apache.hadoop.hbase.client
-
The context, and return value, for a single submit/submitAll call.
- AsyncRequestFutureImpl(AsyncProcessTask, List<Action>, long, AsyncProcess) - Constructor for class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- AsyncRequestFutureImpl.ReplicaCallIssuingRunnable - Class in org.apache.hadoop.hbase.client
-
Runnable (that can be submitted to thread pool) that waits for when it's time to issue replica
calls, finds region replicas, groups the requests by replica and issues the calls (on separate
threads, via sendMultiAction).
- AsyncRequestFutureImpl.ReplicaResultState - Class in org.apache.hadoop.hbase.client
-
Sync point for calls to multiple replicas for the same user request (Get).
- AsyncRequestFutureImpl.Retry - Enum in org.apache.hadoop.hbase.client
-
- AsyncRequestFutureImpl.SingleServerRequestRunnable - Class in org.apache.hadoop.hbase.client
-
Runnable (that can be submitted to thread pool) that submits MultiAction to a single server.
- AsyncRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- AsyncRpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
-
Factory to create an AsyncRpcRetryCaller.
- AsyncRpcRetryingCallerFactory(AsyncConnectionImpl, Timer) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.BatchCallerBuilder - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.BuilderBase - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
-
- AsyncScanSingleRegionRpcRetryingCaller - Class in org.apache.hadoop.hbase.client
-
Retry caller for scanning a region.
- AsyncScanSingleRegionRpcRetryingCaller(Timer, AsyncConnectionImpl, Scan, ScanMetrics, long, ScanResultCache, AdvancedScanResultConsumer, ClientProtos.ClientService.Interface, HRegionLocation, boolean, int, long, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl - Class in org.apache.hadoop.hbase.client
-
- AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState - Enum in org.apache.hadoop.hbase.client
-
- AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl - Class in org.apache.hadoop.hbase.client
-
- AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState - Enum in org.apache.hadoop.hbase.client
-
- AsyncServerRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
Retry caller for a request call to region server.
- AsyncServerRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, long, long, int, long, long, int, ServerName, AsyncServerRequestRpcRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
-
- AsyncServerRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
-
- AsyncSingleRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
Retry caller for a single request, such as get, put, delete, etc.
- AsyncSingleRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, TableName, byte[], int, RegionLocateType, AsyncSingleRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- AsyncSingleRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
-
- asyncSnapshot(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- AsyncTable<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
-
The interface for asynchronous version of Table.
- AsyncTable.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncTable.CheckAndMutateWithFilterBuilder - Interface in org.apache.hadoop.hbase.client
-
- AsyncTable.CoprocessorCallback<R> - Interface in org.apache.hadoop.hbase.client
-
The callback when we want to execute a coprocessor call on a range of regions.
- AsyncTable.CoprocessorServiceBuilder<S,R> - Interface in org.apache.hadoop.hbase.client
-
Helper class for sending coprocessorService request that executes a coprocessor call on regions
which are covered by a range.
- AsyncTableBuilder<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
-
- AsyncTableBuilderBase<C extends ScanResultConsumerBase> - Class in org.apache.hadoop.hbase.client
-
Base class for all asynchronous table builders.
- AsyncTableBuilderBase(TableName, AsyncConnectionConfiguration) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- AsyncTableImpl - Class in org.apache.hadoop.hbase.client
-
- AsyncTableImpl(RawAsyncTableImpl, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- AsyncTableRegionLocator - Interface in org.apache.hadoop.hbase.client
-
The asynchronous version of RegionLocator.
- AsyncTableRegionLocatorImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of AsyncRegionLocator.
- AsyncTableRegionLocatorImpl(TableName, AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- AsyncTableResultScanner - Class in org.apache.hadoop.hbase.client
-
- AsyncTableResultScanner(TableName, Scan, long) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- at(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- atCapacity() - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- atHeadOfRingBufferEventHandlerAppend() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Exposed for testing only.
- atLeast(TableSplit.Version) - Method in enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
-
- atomic - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicBoolean
- ATOMIC_INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicInteger
- ATOMIC_LONG - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicLong
- ATOMIC_REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicReference
- AtomicAverageCounter() - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- AtomicUtils - Class in org.apache.hadoop.hbase.util
-
Utilities related to atomic operations.
- AtomicUtils() - Constructor for class org.apache.hadoop.hbase.util.AtomicUtils
-
- attachRemoteProc(RegionRemoteProcedureBase) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- attainSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- attainSafePoint(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
Check if we should attain safe point.
- attempt - Variable in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- attemptFetch() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
Attempts to fetch the cluster ID from the file system.
- attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider.SaslDigestCallbackHandler
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler
-
- AttemptingUserProvidingSaslServer - Class in org.apache.hadoop.hbase.security.provider
-
Wrapper around a SaslServer which provides the last user attempting to authenticate via SASL, if
the server/mechanism allow figuring that out.
- AttemptingUserProvidingSaslServer(SaslServer, Supplier<UserGroupInformation>) - Constructor for class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
-
- attempts - Variable in class org.apache.hadoop.hbase.util.RetryCounter
-
- attemptToOwnTask(boolean, ZKWatcher, ServerName, String, int) - Static method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
- ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- Attributes - Interface in org.apache.hadoop.hbase.client
-
- attributes - Variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- attributes - Variable in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- attributes - Variable in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
- attributes - Variable in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- attributes - Variable in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
-
- Attributes - Class in org.apache.hadoop.hbase.hbtop.terminal
-
The attributes of text in the terminal.
- Attributes() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- Attributes(Attributes) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- attributes - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- attributes - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- attributes - Variable in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
-
- ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- attrKeyColumnIndex - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- attrs - Variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- attrs - Variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- AUDITLOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AUDITLOG - Static variable in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.access.AccessController
-
- AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- AUTH_COOKIE - Static variable in class org.apache.hadoop.hbase.rest.client.Client
-
- AUTH_COOKIE_EQ - Static variable in class org.apache.hadoop.hbase.rest.client.Client
-
- AUTH_FAILED_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AUTH_SUCCESSFUL_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.provider.AbstractSaslClientAuthenticationProvider
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.provider.BuiltInSaslAuthenticationProvider
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- authenticatedWithFallback - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes classes that can be used to build custom authentication solutions.
- AUTHENTICATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_FALLBACKS_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_FALLBACKS_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationEnabled - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authenticationFailures - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authenticationFallback() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- authenticationFallback() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationFallback() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authenticationFallbacks - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationKey() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- AuthenticationKey(int, long, SecretKey) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
- AuthenticationProviderSelector - Interface in org.apache.hadoop.hbase.security.provider
-
- authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- authenticationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authenticationSuccesses - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
-
Represents the identity information stored in an HBase authentication token.
- AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenSecretManager - Class in org.apache.hadoop.hbase.security.token
-
Manages an internal list of secret keys used to sign new authentication tokens as they are
generated, and to valid existing tokens used for authentication.
- AuthenticationTokenSecretManager(Configuration, ZKWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
Create a new secret manager instance for generating keys.
- AuthenticationTokenSecretManager.LeaderElector - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- authFailedFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- AuthFilter - Class in org.apache.hadoop.hbase.rest.filter
-
- AuthFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
- authManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- authManager - Variable in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- authManager - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- AuthManager - Class in org.apache.hadoop.hbase.security.access
-
Performs authorization checks for a given user's assigned permissions.
- AuthManager(Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.AuthManager
-
- authManager - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- AuthManager.PermissionCache<T extends Permission> - Class in org.apache.hadoop.hbase.security.access
-
Cache of permissions, it is thread safe.
- AuthMethod - Enum in org.apache.hadoop.hbase.security
-
Authentication method
- AuthMethod(byte, String, UserGroupInformation.AuthenticationMethod) - Constructor for enum org.apache.hadoop.hbase.security.AuthMethod
-
- AUTHORIZATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationEnabled - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if we are active, usually false, only true if "hbase.security.authorization" has been set to
true in site configuration
- authorizationEnabled - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
if we are active, usually false, only true if "hbase.security.authorization" has been set to
true in site configuration
- authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- authorizationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authorizationFailures - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- Authorizations - Class in org.apache.hadoop.hbase.security.visibility
-
This class contains visibility labels associated with a Scan/Get deciding which all labeled data
current scan/get can access.
- Authorizations(String...) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- Authorizations(List<String>) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- authorizationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authorizationSuccesses - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authorize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Authorize the incoming client connection.
- authorizeCell(User, TableName, Cell, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in cell scope.
- authorizeConnection() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- authorizeFamily(Set<TablePermission>, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
- authorizeGlobal(GlobalPermission, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
- authorizeNamespace(Set<NamespacePermission>, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
- authorizeTable(Set<TablePermission>, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
- authorizeUserFamily(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in table:family scope.
- authorizeUserGlobal(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in global scope.
- authorizeUserNamespace(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in namespace scope.
- authorizeUserTable(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in table scope.
- authorizeUserTable(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in table:family scope.
- authorizeUserTable(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Check if user has given action privilige in table:family:qualifier scope.
- AuthResult - Class in org.apache.hadoop.hbase.security.access
-
Represents the result of an authorization check for logging and error reporting.
- AuthResult(boolean, String, String, User, Permission.Action, TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, String) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult.Params - Class in org.apache.hadoop.hbase.security.access
-
- authTokenSecretMgr - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AuthUtil - Class in org.apache.hadoop.hbase
-
- AuthUtil() - Constructor for class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
- authz - Variable in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- autoAdjust - Variable in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- avail - Variable in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- AVAIL_PROCESSORS - Static variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- available(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Is HBase available? Throw an exception if not.
- available() - Method in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
- available() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
- available() - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
- available() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- availableServersContains(List<ServerName>, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- AVERAGE_LOAD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- AVERAGE_LOAD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- AVERAGE_REGION_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- AVERAGE_REGION_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- AverageIntervalRateLimiter - Class in org.apache.hadoop.hbase.quotas
-
This limiter will refill resources at every TimeUnit/resources interval.
- AverageIntervalRateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- averageLatency - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- averageLoad - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- averageLoad - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- averageRegionSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- averageRegionSizeMb - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- averageTime - Variable in class org.apache.hadoop.hbase.util.SimpleMovingAverage
-
- AVG_KEY_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- AVG_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- AVG_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- AVG_VALUE_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- avgDispersionNum - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- avgDispersionScore - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Average key length read from file info
- avgLoadOverall - Variable in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- avgRegionsOnRS - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- avgStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- avgStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Average value length read from file info
- avlHeight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
-
- AvlIterableList() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
- avlLeft - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
-
- AvlLinkedNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
-
- AvlNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
-
- avlRight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
-
- AvlTree() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
- AvlTreeIterator() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
- AvlTreeIterator(TNode) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Create the iterator starting from the first (min) node of the tree
- AvlTreeIterator(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Create the iterator starting from the specified key
- AvlUtil - Class in org.apache.hadoop.hbase.util
-
Helper class that allows to create and manipulate an AvlTree.
- AvlUtil() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil
-
- AvlUtil.AvlInsertOrReplace<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
-
- AvlUtil.AvlIterableList - Class in org.apache.hadoop.hbase.util
-
Helper class that allows to create and manipulate a linked list of AvlLinkedNodes
- AvlUtil.AvlKeyComparator<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
-
The AvlTree allows to lookup an object using a custom key.
- AvlUtil.AvlLinkedNode<TNode extends AvlUtil.AvlLinkedNode> - Class in org.apache.hadoop.hbase.util
-
This class extends the AvlNode and adds two links that will be used in conjunction with the
AvlIterableList class.
- AvlUtil.AvlNode<TNode extends AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
-
This class represent a node that will be used in an AvlTree.
- AvlUtil.AvlNodeVisitor<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
-
Visitor that allows to traverse a set of AvlNodes.
- AvlUtil.AvlTree - Class in org.apache.hadoop.hbase.util
-
Helper class that allows to create and manipulate an AVL Tree
- AvlUtil.AvlTreeIterator<TNode extends AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
-
Iterator for the AvlTree
- AVOID_COST - Static variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- await(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- await() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.NoopLatch
-
- await() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Wait until the read point catches up to the write point; i.e.
- awaitRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
- awaitRunning(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
- awaitRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- awaitRunning(long, TimeUnit) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- awaitTerminated() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
- awaitTerminated(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
- awaitTerminated() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- awaitTerminated(long, TimeUnit) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- awaitTermination() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
-
- awaitTermination() - Method in class org.apache.hadoop.hbase.procedure2.StoppableThread
-
- c - Variable in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- c - Variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- cache - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- cache - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- cache - Variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- cache - Variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- CACHE - Static variable in class org.apache.hadoop.hbase.io.compress.DictionaryCache
-
- cache - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.EvictionThread
-
- cache - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
- cache - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- cache - Variable in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- cache - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- cache - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
File cache for HFiles in the completed and currently running snapshots
- CACHE - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- cache - Variable in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- cache - Variable in class org.apache.hadoop.hbase.quotas.QuotaRetriever.Iter
-
- cache - Variable in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- cache - Variable in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- cache - Variable in class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- cache - Variable in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- cache - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- cache - Variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- cache - Variable in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- CACHE_BASE - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- CACHE_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks on write.
- CACHE_BLOOM_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache compound bloom filter blocks on write.
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_BLOOMS_ON_WRITE_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_COMPACTED_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache blocks when a compacted file is written
- CACHE_COMPACTED_BLOCKS_ON_WRITE_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to determine total size in bytes of compacted files beyond which we do not
cache blocks on compaction
- CACHE_DATA_BLOCKS_COMPRESSED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks in compressed and/or encrypted format.
- CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_DATA_ON_READ_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks on read.
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_DATA_ON_WRITE_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- CACHE_INDEX_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache leaf and intermediate-level index blocks on write.
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- CACHE_INDEX_ON_WRITE_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- CACHE_TIME - Static variable in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
-
Cacheable is an interface that allows for an object to be cached.
- CacheableDeserializer<T extends Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
-
Interface for a deserializer.
- CacheableDeserializerIdManager - Class in org.apache.hadoop.hbase.io.hfile
-
- CacheableDeserializerIdManager() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache.
- cacheBlock(BlockCacheKey, Cacheable) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache (defaults to not in-memory).
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
-
Cache only index block with the specified name and buffer
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.client.Get
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.client.Scan
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- cacheBlockWithWait(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block to ramCache
- cacheBlockWithWaitInternal(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- cacheBloomsOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether compound bloom filter blocks should be cached on write
- cacheCapacity - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- cacheCompactedDataOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether data blocks should be cached when compacted file is written
- cacheCompactedDataOnWriteThreshold - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Determine threshold beyond which we do not cache blocks on compaction
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
CacheConfig, or null if cache-on-write is disabled
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Block cache configuration.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Cache configuration for caching data on write.
- cacheConf - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- cacheConf - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
-
- cacheConf - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- cacheConf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
- cacheConf - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
-
Stores all of the cache objects and configuration for a single HFile.
- CacheConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and defaults for family
level settings.
- CacheConfig(Configuration, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- CacheConfig(Configuration, ColumnFamilyDescriptor, BlockCache, ByteBuffAllocator) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and family descriptor.
- CacheConfig(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Constructs a cache configuration copied from the specified configuration.
- CacheConfig() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.ExistsResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.RegionsResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.RootResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.SchemaResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
- cacheControl - Static variable in class org.apache.hadoop.hbase.rest.VersionResource
-
- cached - Variable in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- cached - Variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
A group-provider mapping, make sure one-one rather than many-one mapping
- cacheDataBlockPercent - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Percent of cached data blocks
- cacheDataCompressed - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether data blocks should be stored in compressed and/or encrypted form in the cache
- cacheDataOnRead - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether blocks should be cached on read (default is on if there is a cache but this can be
turned off on a per-family or per-request basis).
- cacheDataOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether data blocks should be cached when new files are written
- CachedBlock - Interface in org.apache.hadoop.hbase.io.hfile
-
- cachedBlockByFile - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Map by filename.
- CachedBlockCountsPerFile(String) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- CachedBlocksByFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- CachedBlocksByFile(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- CachedBlockView(BlockCacheKey, Cacheable, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- CachedClusterId - Class in org.apache.hadoop.hbase.master
-
Caches the cluster ID of the cluster.
- CachedClusterId(Server, Configuration) - Constructor for class org.apache.hadoop.hbase.master.CachedClusterId
-
- cachedClusterId - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- cachedEncodedData - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- CachedEntryQueue - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
A memory-bound queue that will grow until an element brings total size larger than maxSize.
- CachedEntryQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- cachedMetaLocations - Variable in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Cached meta region locations indexed by replica ID.
- CachedMobFile - Class in org.apache.hadoop.hbase.mob
-
Cached mob file.
- CachedMobFile(HStoreFile) - Constructor for class org.apache.hadoop.hbase.mob.CachedMobFile
-
- cachedNext - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
- cachedRegionLocations - Variable in class org.apache.hadoop.hbase.client.MetaCache
-
- cacheDroppingExceptions - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- cachedServers - Variable in class org.apache.hadoop.hbase.client.MetaCache
-
- cachedTerminalSize - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- cachedTime - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
Time this block was cached.
- cachedTime - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Time this block was cached.
- cacheEnabled - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Flag if the cache is enabled or not...
- CacheEvictionStats - Class in org.apache.hadoop.hbase
-
- CacheEvictionStats(CacheEvictionStatsBuilder) - Constructor for class org.apache.hadoop.hbase.CacheEvictionStats
-
- CacheEvictionStatsAggregator - Class in org.apache.hadoop.hbase
-
Used to merge CacheEvictionStats.
- CacheEvictionStatsAggregator() - Constructor for class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- CacheEvictionStatsBuilder - Class in org.apache.hadoop.hbase
-
- CacheEvictionStatsBuilder() - Constructor for class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- cacheFlushCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- cacheFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- cacheFlushSeqNum - Variable in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- cacheFlushSize - Variable in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- CacheFullException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
-
- CacheFullException(int, int) - Constructor for exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- cachehits - Variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- cacheIndexesOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether index blocks should be cached when new files are written
- cacheKey - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- CacheKey(Connection, Configuration, FileSystem, TableName) - Constructor for class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl.CacheKey
-
- cacheLocation(TableName, RegionLocations) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Put a newly discovered HRegionLocation into the cache.
- cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Put a newly discovered HRegionLocation into the cache.
- cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Put a newly discovered HRegionLocation into the cache.
- cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Put a newly discovered HRegionLocation into the cache.
- cacheMissCount - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTunerChore
-
- cacheMissCount - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- cacheMisses - Variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- cacheMobBlocks - Variable in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- cacheMobBlocks - Variable in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- cacheNextBlockHeader(long, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Save away the next blocks header in atomic reference.
- cacheOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
Whether to cache-on-write compound Bloom filter chunks
- cacheOnWriteLogged - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- cachePeriodMs - Variable in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
- cacheRow - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- cacheSize - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- cacheSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- cacheSizeInBytes - Variable in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- cacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- CacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
Class that implements cache metrics.
- CacheStats(String) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- CacheStats(String, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- cacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheStats - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- cacheTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- caching - Variable in class org.apache.hadoop.hbase.client.Scan
-
- caching - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- caching - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- calcCoverage() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Generates a coverage multimap from split key to Regions that start with the split key.
- calcEstimatedSize(Result) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- calcMruCap(int) - Static method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
Calculates the mru cache capacity from the metrics size
- calcNumOfCellsInChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- calcNumReaders(int, float) - Static method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- calcNumWriters(int, float) - Static method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- calcPercentage(long, long) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- calcPriority(int, TableName) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Select the priority for the rpc call.
- calculateAutoBalancedSplits(List<InputSplit>, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the number of MapReduce input splits for the map tasks.
- calculateBackoffTime(ServerName, long) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
Calculates the back-off time for a retrying request to a particular server.
- calculateChecksum(String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
-
Using an encryption algorithm to calculate a checksum, the default encryption algorithm is MD5
- calculateCurrentTerm() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
Calculate and set current term
- calculateHashForKey(ByteBufferExtendedCell) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- calculateHashForKey(Cell) - Method in class org.apache.hadoop.hbase.KeyValue
-
- calculateHeapSizeForBlockKeys(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- calculateHeapSizeForBlockKeys(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- calculateHeapSizeForBlockKeys(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- calculateHMAC(byte[], byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- calculateLocationsForInputSplit(Configuration, TableDescriptor, HRegionInfo, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Compute block locations for snapshot files (which will get the locations for referred hfiles)
only when localityEnabled is true.
- calculateMaxLogFiles(Configuration, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- calculateMaxSteps(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- calculateMerges(int, List<Pair<RegionInfo, RegionInfo>>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
Run through overlaps
and return a list of merges to run.
- calculateMobLengthMap(SetMultimap<TableName, String>) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateNumberOfChunks(int, int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- calculatePlans(TableName) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- calculatePoolSize(String) - Static method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Calculate size for cleaner pool.
- calculateReadCapacityUnit(long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- calculateReadCapacityUnitDiff(long, long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- calculateResultSize(Result) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateResultSize(List<Result>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateReturnCodeByPrevCellAndRC(Filter, Cell, Cell, Filter.ReturnCode) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
For MUST_PASS_ONE, we cannot make sure that when filter-A in filter list return NEXT_COL then
the next cell passing to filterList will be the first cell in next column, because if filter-B
in filter list return SKIP, then the filter list will return SKIP.
- calculateTableMerges(int, List<SortedSet<RegionInfo>>, Collection<Pair<RegionInfo, RegionInfo>>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- calculateTheClosestNextRowKeyForPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
-
When scanning for a prefix the scan should stop immediately after the the last row that has the
specified prefix.
- calculateWriteCapacityUnit(long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- calculateWriteCapacityUnitDiff(long, long) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- call(RegistryProtos.ClientMetaService.Interface, AbstractRpcBasedConnectionRegistry.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- call(AbstractRpcBasedConnectionRegistry.Callable<T>, Predicate<T>, String) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- call(HBaseRpcController, RegistryProtos.ClientMetaService.Interface, RpcCallback<T>) - Method in interface org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry.Callable
-
- call(HBaseRpcController, AdminProtos.AdminService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- call(HBaseRpcController, MasterProtos.MasterService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
Shortcut for build().call()
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- call() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
Shortcut for build().call()
- call() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- call(HBaseRpcController, ClientProtos.ClientService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable
-
- call(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- call(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface) - Method in interface org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller.Callable
-
- call(int) - Method in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- call(ScannerCallableWithReplicas, RpcRetryingCaller<Result[]>, int, boolean) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
-
- call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
-
- call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
-
- call() - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
-
- call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
-
- call(int) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- call(AdminProtos.AdminService.Interface, HBaseRpcController, REQ, RpcCallback<RESP>) - Method in interface org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.AdminRpcCall
-
- call(HBaseRpcController, MasterProtos.MasterService.Interface, PREQ, RawAsyncHBaseAdmin.MasterRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<RESP, PRESP>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- call(MasterProtos.MasterService.Interface, HBaseRpcController, REQ, RpcCallback<RESP>) - Method in interface org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.MasterRpcCall
-
- call(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface, REQ, RawAsyncTableImpl.Converter<PREQ, byte[], REQ>, RawAsyncTableImpl.RpcCall<PRESP, PREQ>, RawAsyncTableImpl.Converter<RESP, HBaseRpcController, PRESP>) - Static method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- call(ClientProtos.ClientService.Interface, HBaseRpcController, REQ, RpcCallback<RESP>) - Method in interface org.apache.hadoop.hbase.client.RawAsyncTableImpl.RpcCall
-
- call(int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
Run RPC call.
- call(int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Computes a result, or throws an exception if unable to do so.
- call(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- call(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
Algo: - we put the query into the execution pool.
- call(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- call(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- call(RpcController, REQUEST) - Method in interface org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper.Operation
-
- call(S, RpcController, RpcCallback<R>) - Method in interface org.apache.hadoop.hbase.client.ServiceCaller
-
Represent the actual protobuf rpc call.
- call(O) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
-
- call(O) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
-
- Call - Class in org.apache.hadoop.hbase.ipc
-
A call waiting for a value.
- Call(int, Descriptors.MethodDescriptor, Message, CellScanner, Message, int, int, RpcCallback<Call>, MetricsConnection.CallStats) - Constructor for class org.apache.hadoop.hbase.ipc.Call
-
- call - Variable in class org.apache.hadoop.hbase.ipc.CallEvent
-
- call - Variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- call(RpcCall, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a server side method, which is invoked over RPC.
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- call(RpcCall, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler, long, int) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure.StoreFileSplitter
-
- call() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure.RegionFlushTask
-
- call() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
This call is the main execution thread of the barriered procedure.
- call() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- call() - Method in class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
-
- call() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- call() - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator.Copier
-
- call(HBaseRpcController) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable
-
- call() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RetryingRpcCallable
-
- Call(Runnable) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- call() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- call() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- call() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperTask
-
- call() - Method in interface org.apache.hadoop.hbase.trace.TraceUtil.ThrowingCallable
-
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.CheckRegionConsistencyWorkItem
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.FileLockCallable
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemHdfsDir
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemHdfsRegionInfo
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemOverlapMerge
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemRegion
-
Deprecated.
- call() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker.MobRegionDirChecker
-
- call() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker.RegionDirChecker
-
- call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
-
- call() - Method in class org.apache.hadoop.hbase.util.MoveWithAck
-
- call() - Method in class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- CALL_DROPPED_EXCEPTION - Static variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- CALL_QUEUE_CODEL_DEFAULT_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_CODEL_DEFAULT_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_CODEL_DEFAULT_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_CODEL_INTERVAL - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_CODEL_LIFO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_CODEL_TARGET_DELAY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_HANDLER_FACTOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_LEN_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
- CALL_QUEUE_QUEUE_BALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_QUEUE_BALANCER_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- CALL_QUEUE_TOO_BIG_EXCEPTION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- CALL_QUEUE_TYPE_CODEL_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
The default, 'fifo', has the least friction but is dumb.
- CALL_QUEUE_TYPE_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_TYPE_FIFO_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- CALL_QUEUE_TYPE_PLUGGABLE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
-
- callable - Variable in class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- callable - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- callable - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- callable - Variable in class org.apache.hadoop.hbase.regionserver.handler.RSProcedureHandler
-
- callable - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RetryingRpcCallable
-
- callback - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- callback - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- callback - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- callback - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- Callback(CompletableFuture<Long>, long, Collection<Channel>, long) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.Callback
-
- callback - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- CALLBACK_PARAM - Static variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
-
- callBlockingMethod(Descriptors.MethodDescriptor, HBaseRpcController, Message, Message, User, Address) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Make a blocking call.
- CallCancelledException - Exception in org.apache.hadoop.hbase.ipc
-
Client side call cancelled.
- CallCancelledException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallCancelledException
-
- callCleanup - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- callCleanupIfNeeded() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- callComplete() - Method in class org.apache.hadoop.hbase.ipc.Call
-
- callCount - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaResultState
-
Number of calls outstanding, or 0 if a call succeeded (even with others outstanding).
- callDetails - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- callDetails - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- CallDroppedException - Exception in org.apache.hadoop.hbase
-
Returned to the clients when their request was discarded due to server being overloaded.
- CallDroppedException() - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- CallDroppedException(String) - Constructor for exception org.apache.hadoop.hbase.CallDroppedException
-
- callDroppedException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- callDroppedException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- caller - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- caller - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- caller - Variable in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- callerBuilder - Variable in class org.apache.hadoop.hbase.client.MasterCoprocessorRpcChannelImpl
-
- callerBuilder - Variable in class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
-
- CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
-
Exception indicating that the remote host making this IPC lost its IPC connection.
- CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- callerFactory - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- callerThread - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- CallEvent - Class in org.apache.hadoop.hbase.ipc
-
Used to tell netty handler the call is cancelled, timeout...
- CallEvent(CallEvent.Type, Call) - Constructor for class org.apache.hadoop.hbase.ipc.CallEvent
-
- CallEvent.Type - Enum in org.apache.hadoop.hbase.ipc
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
-
- callExecutor - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- callIdCnt - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- callInfoMap - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.MasterCoprocessorRpcChannelImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
-
- callMethod(Descriptors.MethodDescriptor, HBaseRpcController, Message, Message, User, Address, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
-
- callObserver() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperation
-
- callObserver() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithoutResult
-
In case of coprocessors which have many kinds of observers (for eg,
RegionCoprocessor
has BulkLoadObserver, RegionObserver, etc), some implementations may not need all observers,
in which case they will return null for that observer's getter.
- callObserver() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
-
- callOpenScanner(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface) - Method in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- callPreMutateCPHook(int, WALEdit, int[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
Runs prePut/preDelete/preIncrement/preAppend coprocessor hook for input mutation in a batch
- CallPriorityComparator(Configuration, PriorityFunction) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor.CallPriorityComparator
-
- CallQueue - Class in org.apache.hadoop.hbase.thrift
-
A BlockingQueue reports waiting time in queue and queue length to ThriftMetrics.
- CallQueue(BlockingQueue<CallQueue.Call>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue
-
- callQueue - Variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- CallQueue.Call - Class in org.apache.hadoop.hbase.thrift
-
- CallQueueInfo - Class in org.apache.hadoop.hbase.ipc
-
- CallQueueInfo() - Constructor for class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- callQueueLenGauge - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- callQueueMethodCountsSummary - Variable in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- callQueueMethodSizeSummary - Variable in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- callQueueSizeInBytes - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a running count of the size in bytes of all outstanding calls whether currently
executing or queued waiting to be run.
- CallQueueTooBigException - Exception in org.apache.hadoop.hbase
-
Returned to clients when their request was dropped because the call queue was too big to accept a
new call.
- CallQueueTooBigException() - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- CallQueueTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.CallQueueTooBigException
-
- callQueueTooBigException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- callQueueTooBigException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- CallRunner - Class in org.apache.hadoop.hbase.ipc
-
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler
.
- CallRunner(RpcServerInterface, RpcCall) - Constructor for class org.apache.hadoop.hbase.ipc.CallRunner
-
On construction, adds the size of this call to the running count of outstanding call sizes.
- callRunner - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler.FifoCallRunner
-
- calls - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- callSender - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- CallSender(String, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
- callsInProgress - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- callsInProgress - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.SingleServerRequestRunnable
-
- CallStats() - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- callStats - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- callsToWrite - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
- callTimedOut() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- callTimedOut() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- callTimedOut() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- callTimeMs - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- callTimeout(Call) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- callTimeout - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
The time, in ms before the call should expire.
- callTimeout(Call) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- callTimeout(Call) - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
- CallTimeoutException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
CallTimeoutException with cause
- callTimer - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
-
- CallTracker(MetricRegistry, String, String, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
-
- CallTracker(MetricRegistry, String, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
-
- callWithoutRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Call the server once only.
- callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- callWithRetries(RetryingCallable<T>, int) - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Retries if invocation fails.
- callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- calSleepTimeMs() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- calSleepTimeMs(long, long, long) - Static method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- Canary - Interface in org.apache.hadoop.hbase.tool
-
- CANARY_TABLE_FAMILY_NAME - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryStatusServlet - Class in org.apache.hadoop.hbase.tool
-
- CanaryStatusServlet() - Constructor for class org.apache.hadoop.hbase.tool.CanaryStatusServlet
-
- CanaryTool - Class in org.apache.hadoop.hbase.tool
-
HBase Canary Tool for "canary monitoring" of a running HBase cluster.
- CanaryTool() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryTool(ExecutorService) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryTool(ExecutorService, CanaryTool.Sink) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryTool(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryTool(Configuration, ExecutorService, CanaryTool.Sink) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool
-
- CanaryTool.Monitor - Class in org.apache.hadoop.hbase.tool
-
A Monitor super-class can be extended by users
- CanaryTool.RegionMonitor - Class in org.apache.hadoop.hbase.tool
-
A monitor for region mode.
- CanaryTool.RegionServerMonitor - Class in org.apache.hadoop.hbase.tool
-
A monitor for regionserver mode
- CanaryTool.RegionServerStdOutSink - Class in org.apache.hadoop.hbase.tool
-
By RegionServer, for 'regionserver' mode.
- CanaryTool.RegionServerTask - Class in org.apache.hadoop.hbase.tool
-
Run a single RegionServer Task and then exit.
- CanaryTool.RegionStdOutSink - Class in org.apache.hadoop.hbase.tool
-
By Region, for 'region' mode.
- CanaryTool.RegionTask - Class in org.apache.hadoop.hbase.tool
-
Run a single Region Task and then exit.
- CanaryTool.RegionTask.TaskType - Enum in org.apache.hadoop.hbase.tool
-
- CanaryTool.RegionTaskResult - Class in org.apache.hadoop.hbase.tool
-
Canary region mode-specific data structure which stores information about each region to be
scanned
- CanaryTool.Sink - Interface in org.apache.hadoop.hbase.tool
-
Sink interface used by the canary to output information
- CanaryTool.StdOutSink - Class in org.apache.hadoop.hbase.tool
-
Simple implementation of canary sink that allows plotting to a file or standard output.
- CanaryTool.ZookeeperMonitor - Class in org.apache.hadoop.hbase.tool
-
- CanaryTool.ZookeeperStdOutSink - Class in org.apache.hadoop.hbase.tool
-
Output for 'zookeeper' mode.
- CanaryTool.ZookeeperTask - Class in org.apache.hadoop.hbase.tool
-
Run a single zookeeper Task and then exit.
- canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
- canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
-
- canBeFlattened() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- cancel() - Method in interface org.apache.hadoop.hbase.client.Cancellable
-
- cancel() - Method in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- cancel() - Method in interface org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- cancel() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- cancel(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Actively cancel a running snapshot.
- cancel(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Method to cancel the Subprocedure by injecting an exception from and external source.
- cancel() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Cancels the compaction progress, setting things to 0.
- cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- CancelableProgressable - Interface in org.apache.hadoop.hbase.util
-
Similar interface as Progressable
but returns a boolean to support
canceling the operation.
- cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- cancelAll(boolean) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- cancelAllChores(boolean) - Method in class org.apache.hadoop.hbase.ChoreService
-
- cancelChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Cancel any ongoing schedules that this chore has with the implementer of this interface.
- cancelChore(ScheduledChore, boolean) - Method in class org.apache.hadoop.hbase.ChoreService
-
Cancel any ongoing schedules that this chore has with the implementer of this interface.
- cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Interrupt the connections to the given ip:port server.
- cancelConnections(ServerName) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Interrupt the connections to the given server.
- Cancellable - Interface in org.apache.hadoop.hbase.client
-
This should be implemented by the Get/Scan implementations that talk to replica regions.
- CancellableRegionServerCallable<T> - Class in org.apache.hadoop.hbase.client
-
This class is used to unify HTable calls with AsyncProcess Framework.
- CancellableRegionServerCallable(Connection, TableName, byte[], RpcController, int, RetryingTimeTracker, int) - Constructor for class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- cancellationCbs - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Client explicitly cancels a lease.
- cancelled - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- cancelled - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- cancelled - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- cancelled - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- cancelled - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- cancelled - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- CancelOnClose(DFSClient) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.CancelOnClose
-
- cancelRequestedCompaction(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- cancelTasks() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
-
This attempts to cancel out all pending and in progress tasks.
- cancelTasks() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
This attempts to cancel out all pending and in progress tasks (interruptions issues) n
- cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- cancelTimer() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- candidate - Variable in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- CandidateGenerator - Class in org.apache.hadoop.hbase.master.balancer
-
Generates a candidate action to be applied to the cluster for cost function search
- CandidateGenerator() - Constructor for class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- candidateGenerators - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- canEnforceBatchLimitFromScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
n * @return true when the limit can be enforced from the scope of the checker
- canEnforceLimitFromScope(ScannerContext.LimitScope) - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
-
- canEnforceSizeLimitFromScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
n * @return true when the limit can be enforced from the scope of the checker
- canEnforceTimeLimitFromScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
n * @return true when the limit can be enforced from the scope of the checker
- canExecute() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Is there at least one resource available to allow execution?
- canExecute(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Are there enough available resources to allow execution?
- canGrow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- canHint - Variable in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- canMerge(BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- canOptimizeForNonNullColumn - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- canPlaceFavoredNodes() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- canProceed - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- canPurge(MonitoredTask) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- canPush(WAL.Entry, byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- canPush(WAL.Entry, Cell) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- canPushUnder - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- CanReinit - Interface in org.apache.hadoop.hbase.io.compress
-
This is a marker interface that indicates if a compressor or decompressor type can support
reinitialization via reinit(Configuration conf).
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- canReplicateToSameCluster() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Whether or not, the replication endpoint can replicate to it's source cluster with the same
UUID
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- canRetry() - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- canRetry() - Method in interface org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProvider
-
Returns true if the implementation is capable of performing some action which may allow a
failed authentication to become a successful authentication.
- canRetryUntil - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
- canSchedule(MasterProcedureEnv, HRegionLocation) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- canSpecifyBindIP - Variable in enum org.apache.hadoop.hbase.thrift.ImplType
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Returns true
if the specified region can be split.
- canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns whether this store is splittable, i.e., no reference file in this store.
- canTakeOperation(HRegionLocation, long) - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestHeapSizeChecker
-
- canTakeOperation(HRegionLocation, long) - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestRowsChecker
-
- canTakeOperation(HRegionLocation, long) - Method in interface org.apache.hadoop.hbase.client.SimpleRequestController.RowChecker
-
- canTakeOperation(HRegionLocation, long) - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.SubmittedSizeChecker
-
- canTakeOperation(HRegionLocation, long) - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
1) check the regions is allowed.
- canTakeRow(HRegionLocation, Row) - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
-
Checks the data whether it is valid to submit.
- canTryMore(int) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
We stop to retry when we have exhausted BOTH the number of tries and the time allocated.
- canUpdateOnError(HRegionLocation, HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- canUserModifyUI(HttpServletRequest, ServletContext, Configuration) - Static method in class org.apache.hadoop.hbase.http.InfoServer
-
Returns true if and only if UI authentication (spnego) is enabled, UI authorization is enabled,
and the requesting user is defined as an administrator.
- CAPACITY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
Anticipated number of metric entries
- capacity - Variable in class org.apache.hadoop.hbase.io.asyncfs.SendBufSizePredictor
-
- capacity - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
- capacity - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- capacity() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the total capacity of this ByteBuff.
- capacity() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the total capacity of this MultiByteBuffer.
- capacity() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- capitalize(String) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- carryForwardTags(Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Returns A List<Tag> of any Tags found in cell
else null.
- carryForwardTags(List<Tag>, Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Add to tagsOrNull
any Tags cell
is carrying or null if none.
- carryForwardTTLTag(List<Tag>, long) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Returns Carry forward the TTL tag.
- carryingMeta - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- cast(Class<?>) - Static method in class org.apache.hadoop.hbase.util.Classes
-
- castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
The response message comes as type S.
- castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToReturnType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
provides casting opportunity between the data types.
- CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family
- CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family as a string
- CatalogJanitor - Class in org.apache.hadoop.hbase.master.janitor
-
A janitor for the catalog tables.
- CatalogJanitor(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- CatalogJanitor.SplitParentFirstComparator - Class in org.apache.hadoop.hbase.master.janitor
-
Compare HRegionInfos in a way that has split parents sort BEFORE their daughters.
- catalogJanitorChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- CatalogJanitorReport - Class in org.apache.hadoop.hbase.master.janitor
-
Report made by ReportMakingVisitor
- CatalogJanitorReport() - Constructor for class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the catalog janitor/
- catalogJanitorSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the catalog janitor on/off.
- catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- catalogJanitorSwitch(boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- CatalogReplicaLoadBalanceSelector - Interface in org.apache.hadoop.hbase.client
-
A Catalog replica selector decides which catalog replica to go for read requests when it is
configured as CatalogReplicaMode.LoadBalance.
- CatalogReplicaLoadBalanceSelectorFactory - Class in org.apache.hadoop.hbase.client
-
- CatalogReplicaLoadBalanceSelectorFactory() - Constructor for class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSelectorFactory
-
Private Constructor
- CatalogReplicaLoadBalanceSimpleSelector - Class in org.apache.hadoop.hbase.client
-
CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing
algorithm.
- CatalogReplicaLoadBalanceSimpleSelector(TableName, ChoreService, IntSupplier) - Constructor for class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry - Class in org.apache.hadoop.hbase.client
-
StaleLocationCacheEntry is the entry when a stale location is reported by an client.
- CatalogReplicaMode - Enum in org.apache.hadoop.hbase
-
There are two modes with catalog replica support.
- CatalogReplicaMode() - Constructor for enum org.apache.hadoop.hbase.CatalogReplicaMode
-
- CatalogReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
ReplicationSource that reads catalog WAL files -- e.g.
- CatalogReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.CatalogReplicationSource
-
- catalogReplicationSource - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
A special ReplicationSource for hbase:meta Region Read Replicas.
- CatalogReplicationSourcePeer - Class in org.apache.hadoop.hbase.replication.regionserver
-
The 'peer' used internally by Catalog Region Replicas Replication Source.
- CatalogReplicationSourcePeer(Configuration, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.CatalogReplicationSourcePeer
-
- cause - Variable in exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
-
- cause - Variable in exception org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler.TIOErrorWithCause
-
- cbh - Variable in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- cBuf - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslWrapHandler
-
- cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- cConnection - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- ceiling(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- ceiling(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- ceilingEntry(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- ceilingEntry(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- ceilingKey(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- ceilingKey(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- Cell - Interface in org.apache.hadoop.hbase
-
The unit of storage in HBase consisting of the following fields:
- cell - Variable in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- cell - Variable in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- cell - Variable in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- Cell - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
Represents a single text cell of the terminal.
- Cell() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- cell - Variable in class org.apache.hadoop.hbase.mob.MobCell
-
- cell - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- cell - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- cell - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapEntry
-
- Cell() - Constructor for class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- Cell(long) - Constructor for class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- cell - Variable in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- Cell.Type - Enum in org.apache.hadoop.hbase
-
The valid types for user to build the cell.
- CELL_ARRAY_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CellArrayMap
- CELL_ARRAY_MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for Cell Array Entry
- CELL_CHUNK_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CellChunkMap
- CELL_CHUNK_MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for Cell Chunk Map Entry
- CELL_FLAT_MAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CellFlatMap
- CELL_NOT_BASED_ON_CHUNK - Static variable in interface org.apache.hadoop.hbase.ExtendedCell
-
- CELL_SET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CellSkipListSet
- CELL_TTL_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CELL_VISIBILITY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CellArrayImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
- CellArrayImmutableSegment(CellComparator, MemStoreSegmentsIterator, MemStoreLAB, int, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used when
new CellArrayImmutableSegment is a result of compaction of a list of older ImmutableSegments.
- CellArrayImmutableSegment(CSLMImmutableSegment, MemStoreSizing, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used when
new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The
given iterator returns the Cells that "survived" the compaction.
- CellArrayMap - Class in org.apache.hadoop.hbase.regionserver
-
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.
- CellArrayMap(Comparator<? super Cell>, Cell[], int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellArrayMap
-
- CellBasedKeyBlockIndexReader(CellComparator, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- cellBlock - Variable in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- CellBlockBuilder - Class in org.apache.hadoop.hbase.ipc
-
Helper class for building cell block.
- CellBlockBuilder(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
- cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- cellBlockBuilder - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- CellBlockBuilder.ByteBufferOutputStreamSupplier - Class in org.apache.hadoop.hbase.ipc
-
- CellBlockBuilder.ByteBufOutputStreamSupplier - Class in org.apache.hadoop.hbase.ipc
-
- CellBlockBuilder.OutputStreamSupplier - Interface in org.apache.hadoop.hbase.ipc
-
- cellBlockBuildingInitialBufferSize - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
- cellBlockDecompressionMultiplier - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
How much we think the decompressor will expand the original compressed content.
- cellBlockStream - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- CellBuilder - Interface in org.apache.hadoop.hbase
-
- cellBuilder - Variable in class org.apache.hadoop.hbase.codec.CellCodec.CellDecoder
-
- cellBuilder - Variable in class org.apache.hadoop.hbase.codec.CellCodecWithTags.CellDecoder
-
- cellBuilder - Variable in class org.apache.hadoop.hbase.codec.MessageCodec.MessageDecoder
-
- cellBuilder - Variable in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- cellBuilder - Variable in class org.apache.hadoop.hbase.replication.BulkLoadCellFilter
-
- CellBuilderFactory - Class in org.apache.hadoop.hbase
-
Create a CellBuilder instance.
- CellBuilderFactory() - Constructor for class org.apache.hadoop.hbase.CellBuilderFactory
-
- CellBuilderType - Enum in org.apache.hadoop.hbase
-
- CellBuilderType() - Constructor for enum org.apache.hadoop.hbase.CellBuilderType
-
- CellChunkImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
- CellChunkImmutableSegment(CellComparator, MemStoreSegmentsIterator, MemStoreLAB, int, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used when
new CellChunkImmutableSegment is built as a result of compaction/merge of a list of older
ImmutableSegments.
- CellChunkImmutableSegment(CSLMImmutableSegment, MemStoreSizing, MemStoreCompactionStrategy.Action) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used when
new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The
given iterator returns the Cells that "survived" the compaction.
- CellChunkMap - Class in org.apache.hadoop.hbase.regionserver
-
CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell
data) and can be allocated both off-heap and on-heap.
- CellChunkMap(Comparator<? super Cell>, Chunk[], int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellChunkMap
-
C-tor for creating CellChunkMap from existing Chunk array, which must be ordered (decreasingly
or increasingly according to parameter "descending")
- CellCodec - Class in org.apache.hadoop.hbase.codec
-
Basic Cell codec that just writes out all the individual elements of a Cell.
- CellCodec() - Constructor for class org.apache.hadoop.hbase.codec.CellCodec
-
- CellCodec.CellDecoder - Class in org.apache.hadoop.hbase.codec
-
- CellCodec.CellEncoder - Class in org.apache.hadoop.hbase.codec
-
- cellCodecClsName - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrContext
-
- CellCodecWithTags - Class in org.apache.hadoop.hbase.codec
-
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
- CellCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- CellCodecWithTags.CellDecoder - Class in org.apache.hadoop.hbase.codec
-
- CellCodecWithTags.CellEncoder - Class in org.apache.hadoop.hbase.codec
-
- CellComparator - Interface in org.apache.hadoop.hbase
-
Comparator for comparing cells and has some specialized methods that allows comparing individual
cell components like row, family, qualifier and timestamp
- cellComparator - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- cellComparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- cellComparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- cellComparator - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- cellComparator - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- cellComparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- CellComparatorImpl - Class in org.apache.hadoop.hbase
-
Compare two HBase cells.
- CellComparatorImpl() - Constructor for class org.apache.hadoop.hbase.CellComparatorImpl
-
- cellCount - Variable in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- CellCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a a map and reduce phase to count cells in a table.
- CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- CellCounter.CellCounterMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Mapper that runs the count.
- CellCounter.CellCounterMapper.Counters - Enum in org.apache.hadoop.hbase.mapreduce
-
Counter enumeration to count the actual rows.
- CellCounter.LongSumReducer<Key> - Class in org.apache.hadoop.hbase.mapreduce
-
- CellCounterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- CellCreator - Class in org.apache.hadoop.hbase.mapreduce
-
Facade to create Cells for HFileOutputFormat.
- CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- CellDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.CellCodec.CellDecoder
-
- CellDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags.CellDecoder
-
- cellDecoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- CellDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
-
- CellEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.CellCodec.CellEncoder
-
- CellEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags.CellEncoder
-
- cellEncoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- cellFeaturesEnabled - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if we are able to support cell ACLs
- cellFilters - Variable in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- CellFlatMap - Class in org.apache.hadoop.hbase.regionserver
-
CellFlatMap stores a constant number of elements and is immutable after creation stage.
- CellFlatMap(Comparator<? super Cell>, int, int, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- CellFlatMap.CellFlatMapCollection - Class in org.apache.hadoop.hbase.regionserver
-
- CellFlatMap.CellFlatMapEntry - Class in org.apache.hadoop.hbase.regionserver
-
- CellFlatMap.CellFlatMapIterator - Class in org.apache.hadoop.hbase.regionserver
-
- CellFlatMapCollection() - Constructor for class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- CellFlatMapEntry(Cell) - Constructor for class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapEntry
-
- CellFlatMapIterator() - Constructor for class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapIterator
-
- cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.
- cellFromHBase(Cell[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array.
- CellHashKey - Class in org.apache.hadoop.hbase.util
-
Extracts the byte for the hash calculation from the given cell
- CellHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.CellHashKey
-
- CellImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
-
- CellModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a cell.
- CellModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Default constructor
- CellModel(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor nn
- CellModel(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor nnn
- CellModel(Cell) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor from KeyValue n
- CellModel(byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor nnn
- CellModel(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor nnnn
- CellOutputStream - Interface in org.apache.hadoop.hbase.io
-
Accepts a stream of Cells.
- CellReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellReducer
-
- cells - Variable in class org.apache.hadoop.hbase.client.Result
-
- cells - Variable in class org.apache.hadoop.hbase.ipc.Call
-
Optionally has cells when making call.
- cells - Variable in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- cells - Variable in class org.apache.hadoop.hbase.rest.model.RowModel
-
- cells - Variable in class org.apache.hadoop.hbase.util.Counter.Container
-
Deprecated.
The length should be a power of 2.
- cells - Variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- CELLS_COUNT_COMPACTED_FROM_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_COUNT_COMPACTED_FROM_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_COUNT_COMPACTED_TO_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_COUNT_COMPACTED_TO_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_SIZE_COMPACTED_FROM_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_SIZE_COMPACTED_FROM_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_SIZE_COMPACTED_TO_MOB - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CELLS_SIZE_COMPACTED_TO_MOB_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CellScannable - Interface in org.apache.hadoop.hbase
-
Implementer can return a CellScanner over its Cell content.
- cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
-
Returns A CellScanner over the contained
Cell
s
- CellScanner - Interface in org.apache.hadoop.hbase
-
An interface for iterating through a sequence of cells.
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- cellScanner - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
They are optionally set on construction, cleared after we make the call, and then optionally
set on response with the result.
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
Returns One-shot cell scanner (you cannot back it up and restart)
- cellScanner - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- CellScanner(Iterator<Result>) - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.CellScanner
-
- CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
-
Thrown if a cellscanner but no codec to encode it with.
- CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
-
- cellScannerIndex - Variable in class org.apache.hadoop.hbase.client.Result
-
Index for where we are when Result is acting as a
CellScanner
.
- cellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- cellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- cellsCount - Variable in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- cellsCount - Variable in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- cellsCountCompactedFromMob - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- cellsCountCompactedFromMob - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- cellsCountCompactedToMob - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- cellsCountCompactedToMob - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- CellSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
Use to specify the type of serialization for the mappers and reducers
- CellSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- CellSerialization.CellDeserializer - Class in org.apache.hadoop.hbase.mapreduce
-
- CellSerialization.CellSerializer - Class in org.apache.hadoop.hbase.mapreduce
-
- CellSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
-
- CellSet - Class in org.apache.hadoop.hbase.regionserver
-
A
Set
of
Cell
s, where an add will overwrite the entry if already exists
in the set.
- CellSet(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.CellSet
-
- CellSet(NavigableMap<Cell, Cell>, int) - Constructor for class org.apache.hadoop.hbase.regionserver.CellSet
-
- CellSet(NavigableMap<Cell, Cell>) - Constructor for class org.apache.hadoop.hbase.regionserver.CellSet
-
- cellSet - Variable in class org.apache.hadoop.hbase.regionserver.Segment
-
- CellSetModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a grouping of cells.
- CellSetModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Constructor
- CellSetModel(List<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- CellSetModelStream() - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- CellSetModelStream(ArrayList<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- cellsInCurrentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- cellsInCurrentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- CellSink - Interface in org.apache.hadoop.hbase.regionserver
-
A sink of cells that allows appending cells to the Writers that implement it.
- CellSortImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
-
- CellSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Cells.
- CellSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellSortReducer
-
- cellsPerHeartbeatCheck - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- cellsPerTimeoutCheck - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- cellsSeen - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- cellsSeenInPrevious - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- cellsSizeCompactedFromMob - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- cellsSizeCompactedFromMob - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- cellsSizeCompactedToMob - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- cellsSizeCompactedToMob - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- cellToStringMap(Cell) - Static method in class org.apache.hadoop.hbase.client.Mutation
-
- cellTTLColumnIndex - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful for slinging
Cell
instances.
- CellUtil() - Constructor for class org.apache.hadoop.hbase.CellUtil
-
Private constructor to keep this class from being instantiated.
- CellVisibility - Class in org.apache.hadoop.hbase.security.visibility
-
This contains a visibility expression which can be associated with a cell.
- CellVisibility(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- cellVisibilityColumnIndex - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Cell visibility expr
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CellWrapper(Cell) - Constructor for class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- CellWritableComparable() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
-
- CellWritableComparable(Cell) - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
-
- CellWritableComparablePartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
-
- CellWritableComparator() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator
-
- CF_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Configuration or CF schema option for early termination of access checks if table or CF
permissions grant access.
- CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- cfBloomType - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Bloom filter type specified in column family configuration.
- CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- cfName - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- cfRenameMap - Variable in class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
-
- cfRenameMap - Variable in class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
-
- cfRenameMap - Variable in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- cfRenameMap - Variable in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
Deprecated.
- cfRenameMap - Variable in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
-
Deprecated.
- cfs - Variable in class org.apache.hadoop.hbase.client.replication.TableCFs
-
- cfVsMaxVersions - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- cfVsMaxVersions - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- ch - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- chain - Variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
- ChainWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
A
WALEntryFilter
which contains multiple filters and applies them in chain order
- ChainWALEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- ChainWALEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- chance - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- changeConstraintEnabled(HTableDescriptor, Class<? extends Constraint>, boolean) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Change the whether the constraint (if it is already present) is enabled or disabled.
- changed - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- changedReaderObservers - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
-
If set of MapFile.Readers in Store change, implementors are notified.
- changeFAR(boolean) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- changeFR(boolean) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- changesAfterLastFlush - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- channel - Variable in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener
-
- channel - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- channel - Variable in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- channel - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- channel - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- CHANNEL_READER - Static variable in class org.apache.hadoop.hbase.nio.ByteBuff
-
- channelActive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- channelActive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- channelAllocator - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- channelClass - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
- channelClass - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- channelClass - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- channelClass - Variable in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
- channelDataRead(ReadableByteChannel, ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- channelGroup - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- channelGroup - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.AckHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslUnwrapHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- channelInactive(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
-
- channelIO(ReadableByteChannel, WritableByteChannel, ByteBuffer) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- channelLocks - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- channelRead0(ChannelHandlerContext, DatagramPacket) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener.ClusterStatusHandler
-
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- channelRead0(ChannelHandlerContext, DataTransferProtos.PipelineAckProto) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.AckHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.DecryptHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslUnwrapHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerPreambleHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
-
- channelWrite(GatheringByteChannel, BufferChain) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- CHAOS_AGENT_REGISTRATION_EPIMERAL_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- CHAOS_AGENT_STATUS_PERSISTENT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- CHAOS_TEST_ROOT_ZNODE - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- ChaosAgent - Class in org.apache.hadoop.hbase.chaos
-
An agent for executing destructive actions for ChaosMonkey.
- ChaosAgent(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- ChaosAgent.LocalShell - Class in org.apache.hadoop.hbase.chaos
-
Executes Command locally.
- CHAOSAGENT_SHELL_USER - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- ChaosConstants - Class in org.apache.hadoop.hbase.chaos
-
ChaosConstant holds a bunch of Choas-related Constants
- ChaosConstants() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- ChaosService - Class in org.apache.hadoop.hbase.chaos
-
Class used to start/stop Chaos related services (currently chaosagent)
- ChaosService() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosService
-
- ChaosService.ChaosServiceName - Enum in org.apache.hadoop.hbase.chaos
-
- ChaosService.ExecutorAction - Enum in org.apache.hadoop.hbase.chaos
-
- ChaosServiceName() - Constructor for enum org.apache.hadoop.hbase.chaos.ChaosService.ChaosServiceName
-
- ChaosServiceStart(Configuration, ChaosService.ChaosServiceName) - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
-
- ChaosServiceStop() - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
-
- ChaosUtils - Class in org.apache.hadoop.hbase.chaos
-
ChaosUtils holds a bunch of useful functions like getting hostname and getting ZooKeeper quorum.
- ChaosUtils() - Constructor for class org.apache.hadoop.hbase.chaos.ChaosUtils
-
- character(Character) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- character - Variable in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- charset - Variable in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
-
Check a
Put
to ensure it is valid for the table.
- check(DataTransferProtos.DataTransferEncryptorMessageProto) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- check(long, long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
-
- check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
-
- check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
-
- check(Mutation) - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
-
- check(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Checks the given
Mutation
against
this
policy.
- check - Variable in class org.apache.hadoop.hbase.rest.RowResource
-
- CHECK_AND_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_AND_DELETE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- CHECK_AND_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_AND_MUTATE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- CHECK_AND_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_AND_PUT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- CHECK_APPEND - Static variable in class org.apache.hadoop.hbase.rest.RowResource
-
- CHECK_AUTHS_FOR_MUTATION - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- CHECK_COVERING_PERM - Static variable in class org.apache.hadoop.hbase.security.access.AccessController
-
- CHECK_DELETE - Static variable in class org.apache.hadoop.hbase.rest.RowResource
-
- CHECK_INCREMENT - Static variable in class org.apache.hadoop.hbase.rest.RowResource
-
- CHECK_MUTATE_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_FAILED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_PASSED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_PASSED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_OWNER_SET_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- CHECK_PUT - Static variable in class org.apache.hadoop.hbase.rest.RowResource
-
- checkACLForSuperUsers(String[], List<ACL>) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- checkAllBytesParsed() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- checkAndAddToActiveSize(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
Check whether anything need to be done based on the current active set size.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndDelete(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
Validates the input request parameters, parses columns from CellSetModel, and invokes
checkAndDelete on HTable.
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndDeleteFiles(List<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Run the given files through each of the cleaners to see if it should be deleted, deleting it if
necessary.
- checkAndDeleteHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- checkAndDeleteTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- checkAndFixConsistency() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check consistency of all regions that have been found in previous phases.
- checkAndFixReplication() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkAndFixTableStates() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check and fix table states, assumes full info available: - tableInfos - empty tables loaded
- checkAndGet(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.client.SimpleRequestController
-
- checkAndGet(Configuration, String, long) - Static method in class org.apache.hadoop.hbase.client.SimpleRequestController
-
- checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Called when a new Coprocessor class needs to be loaded.
- checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- checkAndGetInstance(Class<?>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- checkAndGetReversed(List<Filter>, boolean) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- checkAndGetSizeAsInt(long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Returns Check onDiskSizeWithHeaderL
size is healthy and then return it as an int
- checkAndGetTableName(byte[], AtomicReference<TableName>, CompletableFuture<TableName>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- checkAndLoadInstance(Class<?>, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- checkAndMarkRunningHbck(Configuration, RetryCounter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
This method maintains a lock using a file.
- checkAndMergeCPMutations(MiniBatchOperationInProgress<Mutation>, List<Region.RowLock>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
checkAndMutate that atomically checks if a row matches the specified condition.
- checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Batch version of checkAndMutate.
- checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- checkAndMutate(byte[], Filter) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- checkAndMutate(List<CheckAndMutate>) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- CheckAndMutate - Class in org.apache.hadoop.hbase.client
-
Used to perform CheckAndMutate operations.
- CheckAndMutate(byte[], byte[], byte[], CompareOperator, byte[], TimeRange, Row) - Constructor for class org.apache.hadoop.hbase.client.CheckAndMutate
-
- CheckAndMutate(byte[], Filter, TimeRange, Row) - Constructor for class org.apache.hadoop.hbase.client.CheckAndMutate
-
- checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndMutate(byte[], Filter) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.client.HTable
-
- checkAndMutate(List<CheckAndMutate>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- checkAndMutate(byte[], Filter) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- checkAndMutate(List<CheckAndMutate>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- checkAndMutate(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], Filter) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.client.Table
-
checkAndMutate that atomically checks if a row matches the specified condition.
- checkAndMutate(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch version of checkAndMutate.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- checkAndMutate(byte[], Filter, TimeRange, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutate(CheckAndMutate, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndMutate(byte[], Filter, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndMutate(byte[], Filter, TimeRange, Mutation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndMutate(CheckAndMutate) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Atomically checks if a row matches the conditions and if it does, it performs the actions.
- checkAndMutate(HRegion, List<ClientProtos.Action>, CellScanner, ClientProtos.Condition, long, ActivePolicyEnforcement) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkAndMutate(HRegion, OperationQuota, ClientProtos.MutationProto, CellScanner, ClientProtos.Condition, long, ActivePolicyEnforcement) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- checkAndMutate(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- checkAndMutate(byte[], Filter) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- checkAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- checkAndMutate(List<CheckAndMutate>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- checkAndMutate(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TCompareOp, ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- CheckAndMutate.Builder - Class in org.apache.hadoop.hbase.client
-
A builder class for building a CheckAndMutate object.
- checkAndMutateAll(List<CheckAndMutate>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch checkAndMutate.
- CheckAndMutateBuilderImpl(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- CheckAndMutateBuilderImpl(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- CheckAndMutateBuilderImpl(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- checkAndMutateChecksFailed - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutateChecksFailed - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- checkAndMutateChecksPassed - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutateChecksPassed - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- checkAndMutateHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- checkAndMutateInternal(CheckAndMutate, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CheckAndMutateResult - Class in org.apache.hadoop.hbase.client
-
Represents a result of a CheckAndMutate operation
- CheckAndMutateResult(boolean, Result) - Constructor for class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
- checkAndMutateTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- CheckAndMutateWithFilterBuilderImpl(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.HTable.CheckAndMutateWithFilterBuilderImpl
-
- CheckAndMutateWithFilterBuilderImpl(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateWithFilterBuilderImpl
-
- checkAndPrepare() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
Validates each mutation and prepares a batch for write.
- checkAndPrepare() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- checkAndPrepare() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- checkAndPrepareMutation(Mutation, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
Helper method that checks and prepares only one mutation.
- checkAndPrepareMutation(int, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- checkAndPreparePut(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
Implement any Put request specific check and prepare logic here.
- checkAndPreparePut(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- checkAndPreparePut(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
During replay, there could exist column families which are removed between region server
failure and replay
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
- checkAndPut(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
Validates the input request parameters, parses columns from CellSetModel, and invokes
checkAndPut on HTable.
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndPutHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- checkAndPutTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- checkAndRecordNewServer(ServerName, ServerMetrics) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check is a server of same host and port already exists, if not, or the existed one got a
smaller start code, record it.
- checkAndResetTimestamp(Cell) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- checkAndRowMutate(byte[], Filter, TimeRange, RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndRowMutate(byte[], byte[], byte[], CompareOperator, ByteArrayComparable, TimeRange, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndRowMutate(byte[], Filter, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndRowMutate(byte[], Filter, TimeRange, RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- checkAndSetZNodeAcls() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
On master start, we check the znode ACLs under the root directory and set the ACLs properly if
needed.
- checkAndSyncTableDescToPeers(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
- checkAndSyncTableToPeerClusters(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Connect to peer and check the table descriptor on peer:
Create the same table on peer when not exist.
Throw an exception if the table already has replication enabled on any of the column
families.
Throw an exception if the table exists on peer cluster but descriptors are not same.
- checkAndUpdateConfigurations(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Check new configuration and update settings if value changed
- checkAndUpdateNamespaceRegionCount(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
Check if adding a region violates namespace quota, if not update namespace cache.
- checkAndUpdateNamespaceRegionCount(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
Check and update region count for an existing table.
- checkAndUpdateNamespaceRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkAndUpdateNamespaceTableCount(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- checkAnyLimitReached(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- checkAnyLimitReached(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- checkArrayBounds(byte[], int, int) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- checkAuths - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- checkAuths(Set<Integer>, int, String, boolean) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- checkBandwidthChangeAndResetThrottler() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- checkBatchLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- checkBatchLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- checkBatchSizeAndLogLargeSize(ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkBeforeBuild() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- checkBit(int, ByteBuff, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Check if bit at specified index is 1.
- checkBlockBoundary() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
At a block boundary, write all the inline blocks and opens new block.
- checkBloomFilterType(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkCallbackName(String) - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Verifies that the callback property, if provided, is purely alphanumeric.
- checkCallingUserAuth() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- checkCanCreateWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- checkCell(Cell) - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- checkCellSizeLimit(HRegion, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkClassLoading(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkClientDisconnect(Optional<RpcCall>) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- checkClockSkew(ServerName, long) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Checks if the clock skew between the server and the master.
- checkClose() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- checkClosed() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- checkClosedRegion(MasterProcedureEnv, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- checkClosedRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- checkClosedRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- checkClusterIdExists(FileSystem, Path, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks that a cluster ID file exists in the HBase root directory
- checkClusterKey(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkCodecs(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Run test on configured codecs to make sure supporting libs are in place.
- checkColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all files in a column family dir.
- checkColumn(Cell, byte) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- checkColumn(ColumnTracker, byte[], int, int, long, byte, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- checkColumn(Cell, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkCompactionPolicy(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkCompression(TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkConfigurationChange(Configuration, Configuration, String...) - Static method in class org.apache.hadoop.hbase.util.CoprocessorConfigurationUtil
-
- checkConfiguredWALEntryFilters(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkCoprocessorWithService(List<MasterCoprocessor>, Class<?>) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Determines if there is a coprocessor implementation in the provided argument which extends or
implements the provided service
.
- checkCoveringPermission(User, AccessController.OpType, RegionCoprocessorEnvironment, byte[], Map<byte[], ? extends Collection<?>>, long, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Determine if cell ACLs covered by the operation grant access.
- checkDaughterInFs(MasterServices, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
Checks if a daughter region -- either splitA or splitB -- still holds references to parent.
- checkDefaultsVersion(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- checkDeleted(DeleteTracker, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Check whether dfs is in safemode.
- checkDifferencesWithOldPlan(Map<TableName, Integer>, Map<String, Map<String, Float>>, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Compares two plans and check whether the locality dropped or increased (prints the information
as a string) also prints the baseline locality
- checkDstSFT(String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- checkEnabledAndUpdate() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Sets the watch on the top-level archive znode, and then updates the monitor with the current
tables that should be archived (and ensures that those nodes are watched as well).
- checkEncryption(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkEndKey(byte[]) - Static method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- checker - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationSourceWALReader
-
- checkExistenceOnly - Variable in class org.apache.hadoop.hbase.client.Get
-
- checkExists(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Check if the specified node exists.
- checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Throws an IOException back out if one is currently stored.
- checkFamilies(Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Check the collection of families for validity.
- checkFamily(Region, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- checkFamily - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- checkFamily(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Checks to see if the file system is still accessible.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Checks to see if the file system is still accessible.
- checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks to see if the specified file system is available
- checkFileVersion(Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
File version check is a little sloppy.
- checkFlushed() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- checkFlushed() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
- checkForClusterFreeHeapMemoryLimit(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Checks whether we have enough heap memory left out after portion for Memstore and Block cache.
- checkForClusterLevelSingleConf(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- checkForCreateTable(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
Pre check when creating a new table.
- checkForDeadOrOnlineServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Check if the set of servers are belong to dead servers list or online servers list.
- checkForErrors() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
-
Check for errors in the writer threads.
- checkFormatVersion(int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Checks the given
HFile
format version, and throws an exception if invalid.
- checkForModifyTable(Configuration, TableDescriptor, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
Pre check when modifying a table.
- checkForNewFamily(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
- checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
- checkForReservedTagPresence(User, Mutation) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkForReservedVisibilityTagPresence(Cell, Pair<Boolean, Tag>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Checks whether cell contains any tag with type as VISIBILITY_TAG_TYPE.
- checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
- checkForStuckWorkers() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- checkForTagsLength(int) - Static method in interface org.apache.hadoop.hbase.RawCell
-
Check the length of tags.
- checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
- checkGeneralBloomFilter(byte[], Cell, BloomFilter) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- checkGroupName(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- checkHasCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- checkHasFamilies(Mutation) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- checkHdfs - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkHdfsIntegrity(boolean, boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkHealth() - Method in class org.apache.hadoop.hbase.HealthChecker
-
- checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks a path to see if it is a valid hfile.
- checkHFileFormatVersionForMob() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
check configured hfile format version before to do compaction
- checkHFilesCountPerRegionPerFamily(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- checkHFileVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- checkHttpSecurity(SaslUtil.QualityOfProtection, Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Checks if the baseznode set as per the property 'zookeeper.znode.parent' exists.
- checkIfCancelled(CancelableProgressable) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
- checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
compare the local machine hostname with region server's hostname to decide if hbase client
connects to a remote region server
- checkIfShouldMoveSystemRegionAsync() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Start a new thread to check if there are region servers whose versions are higher than others.
- checkIfShouldMoveSystemRegionAsync() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkIfShouldMoveSystemRegionAsync() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Called when a new RegionServer is added to the cluster.
- checkIfShouldMoveSystemRegionLock - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- checkIfSyncFailed(SyncFuture) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
- checkIfTimedout(Configuration, long, int, Path, long) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
- checkingEndTimestamp - Variable in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- checkingStartTimestamp - Variable in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- checkInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkInitialized(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- checkIntegrity() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Checks tables integrity.
- checkInterrupt() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Check thread interrupt status and throw an exception if interrupted.
- checkInterval - Static variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- checkIOErrorIsTolerated() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Check whether we tolerate IO error this time.
- checkIsDead(ServerName, String) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called when RegionServer first reports in for duty and thereafter each time it heartbeats to
make sure it is has not been figured for dead.
- checkIsRunning() - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- checkKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Checks that the given Cell's key does not violate the key order.
- checkKeyLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Returns True if v <= 0 or v > current block buffer limit.
- checkKeyValueBytes(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- checkKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Check key and value lengths are wholesome.
- checkKeyValueTagBytes(byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- checkLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Returns True if v < 0 or v > current block buffer limit.
- checkLength(int, int) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- checkLimitOfRows(int, int, boolean, ScannerContext, ClientProtos.ScanResponse.Builder) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkLocationForPrimary(int, Int2IntCounterMap[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Common method for better solution check.
- checkLockPermissions(User, String, TableName, RegionInfo[], String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- checkLockPermissions(ObserverContext<?>, String, TableName, RegionInfo[], String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkLockPermissions(User, String, TableName, RegionInfo[], String) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- checkLog4jProperties() - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- checkLogLowReplication(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- checkLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Schedule a log roll if needed.
- checkLowReplication(long) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
we need to check low replication in period, see HBASE-18132
- checkLowReplicationInterval - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- checkMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- checkMetaLoaded(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Used to check if the meta loading is done.
- checkMetaOnly - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkMetaRegion() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check values in regionInfo for hbase:meta Check if zero or more than one regions with
hbase:meta are found.
- checkMinFilesCriteria(ArrayList<HStoreFile>, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- checkMobColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all files in a mob column family dir.
- checkMobFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks a path to see if it is a valid mob file.
- checkMobIntegrity - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- checkMobRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks all the mob files of a table.
- checkMutationType(Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkNamespacesAndTableCfsConfigConflict(Set<String>, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
Set a namespace in the peer config means that all tables in this namespace will be replicated
to the peer cluster.
- checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkNegativeMemStoreDataSize(long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkNext() - Method in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- checkNoTableNames() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- checkObsoleteConfigurations() - Method in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- checkOnline() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- checkOnline(MasterProcedureEnv, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
Check region is online.
- checkOnlineRegionsReport(ServerStateNode, Set<byte[]>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Check that what the RegionServer reports aligns with the Master's image.
- checkOnlineServersOnly(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- checkOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
StoreFiles will not be scanned.
- checkOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
MemStore will not be scanned.
- checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
-
Take actions on the event of an OutOfMemoryError.
- checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Called to verify that this server is up and running.
- checkOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- checkOrphan(Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Checks if the output table exists and is enabled.
- checkOwnerSet - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- checkParameters(byte[], int, byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Checks the parameters passed to a constructor.
- checkPeerConfig(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkPeerExists(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkPeriod - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- checkPermission(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- checkPermissions(HBaseProtos.ProcedureDescription, AccessChecker, User) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- checkPermissions(HBaseProtos.ProcedureDescription, AccessChecker, User) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- checkPermissions(HBaseProtos.ProcedureDescription, AccessChecker, User) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Check for required permissions before executing the procedure.
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkpoint - Variable in class org.apache.hadoop.hbase.mapreduce.SampleUploader.Uploader
-
- checkPrincipalMatch(Configuration, String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
- checkProcessTimeAndSpeed(DatanodeInfo, long, long, long, int) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
Check if the packet process time shows that the relevant datanode is a slow node.
- checkQueuesDeleted(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
-
- checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- checkQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- checkQuota(int, int, int) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Checks if it is possible to execute the specified operation.
- checkQuota(long, long, long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Checks if it is possible to execute the specified operation.
- checkQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(Region, List<ClientProtos.Action>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(Region, int, int, int) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- checkQuota() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- checkQuotaSupport() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkQuotaTableExists() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Checks if hbase:quota exists in hbase:meta
- checkQuotaToCreateTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Check quota to create table.
- checkQuotaToSplitRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- checkQuotaToUpdateRegion(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Check and update region count quota for an existing table.
- checkReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- checkReadonly() - Method in class org.apache.hadoop.hbase.client.Result
-
All methods modifying state of Result object must call this method to ensure that special
purpose immutable Results can't be accidentally modified.
- checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkReadOnlyMode() - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkReadsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkReady(ProcedureTree.Entry, Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- checkRefCount() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Methods for reference count
- checkRegionBoundaries - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
Check the region chain (from META) of this table.
- checkRegionConsistency(String, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check a single region for consistency and correct deployment.
- checkRegionConsistencyConcurrently(List<HBaseFsck.CheckRegionConsistencyWorkItem>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check consistency of all regions using multiple threads concurrently.
- CheckRegionConsistencyWorkItem(String, HbckRegionInfo) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck.CheckRegionConsistencyWorkItem
-
Deprecated.
- checkRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all column families in a region dir.
- checkRegionIndexValid(int, Pair<byte[][], byte[][]>, TableName) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
we can consider there is a region hole in following conditions.
- checkRegionInfoOnFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Write out an info file under the stored region directory.
- checkRegions(String[]) - Method in interface org.apache.hadoop.hbase.tool.Canary
-
Run Canary in Region mode.
- checkRegions(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- checkRegionsAndGetTableName(byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- checkRegionServers(String[]) - Method in interface org.apache.hadoop.hbase.tool.Canary
-
Runs Canary in Region server mode.
- checkRegionServers(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- checkRegionsToMerge(MasterProcedureEnv, RegionInfo[], boolean) - Static method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- checkReopened(HRegionLocation) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Check whether the region has been reopened.
- checkReplicaId(int) - Static method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- checkReplicationScope(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- checkRequiredOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterCommandLineParser
-
- checkResources() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Check if resources to support an update.
- checkRootDir(Path, Configuration, FileSystem) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Get the rootdir.
- checkRow(byte[]) - Static method in class org.apache.hadoop.hbase.client.Mutation
-
- checkRow(byte[], int, int) - Static method in class org.apache.hadoop.hbase.client.Mutation
-
- checkRow(ByteBuffer) - Static method in class org.apache.hadoop.hbase.client.Mutation
-
- checkRow(Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
-
- checkRow - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- checkRow(Row, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkRow(byte[], String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Make sure this is a valid row for the HRegion
- checkRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- checkRSQuotaToEnableExceedThrottle(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- checkSameClusterKey(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- checkSaslComplete() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- checkScanNextCallSeq(ClientProtos.ScanRequest, RSRpcServices.RegionScannerHolder) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkScanOrder(Cell, Cell, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- checkScanOrder(Cell, Cell, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Check whether scan as expected order nnnn
- checkServer(RegionLocations) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
Run through referenced servers and save off unknown and the dead.
- checkServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Check servers and tables.
- checkServiceStarted() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Check if short circuit read buffer size is set and if not, set it to hbase value.
- checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Check if short circuit read buffer size is set and if not, set it to hbase value.
- checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
- checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- checkSizeAndGrow(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- checkSizeLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- checkSizeLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- checkSnapshotSupport() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Throws an exception if snapshot operations (take a snapshot, restore, clone) are not supported.
- checkSnapshotSupport(Configuration, MasterFileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Called at startup, to verify if snapshot operation is supported, and to avoid starting the
master if there're snapshots present but the cleaners needed are missing.
- checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkSplit(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return the split point.
- checkSplittable(MasterProcedureEnv, RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Check whether the region is splittable
- checkStagingDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Check permissions for bulk load staging directory.
- checkStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
-
- checkState(Configuration, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- checkSubDir(Path, String) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Make sure the directories under rootDir have good permissions.
- CHECKSUM_BUF_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
- CHECKSUM_FAILURES - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
- CHECKSUM_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
- CHECKSUM_FAILURES_KEY - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
- CHECKSUM_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- CHECKSUM_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Each checksum value is an integer that can be stored in 4 bytes.
- CHECKSUM_TYPE_INDEX - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Header
-
- CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The name of the configuration parameter that specifies the name of an algorithm that is used to
compute checksums for newly created blocks.
- CHECKSUM_VERIFICATION_NUM_IO_THRESHOLD - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
On a checksum failure, do these many succeeding read requests using hdfs checksums before
auto-reenabling hbase checksum verification.
- checksumOk() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Report that checksum was ok, so we may ponder going back to HBase checksum.
- checksumType - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
the checksum type
- checkSumType - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
the checksum type
- ChecksumType - Enum in org.apache.hadoop.hbase.util
-
Checksum types.
- ChecksumType(byte) - Constructor for enum org.apache.hadoop.hbase.util.ChecksumType
-
- ChecksumUtil - Class in org.apache.hadoop.hbase.io.hfile
-
Utility methods to compute and validate checksums.
- ChecksumUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
- checkSystemOrSuperUser(User) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkTableDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all the regiondirs in the specified tableDir n * path to a table n
- checkTableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check if table exists or not
- checkTableExists(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkTableModifiable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkTableModifiable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Check table is modifiable; i.e.
- checkTableModifiable(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
Check whether a table is modifiable - exists and either offline or online with config set
- checkTableName(TableName) - Static method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check the specified table dirs for bad hfiles.
- checkTableTypeAndThrowException(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- checkTagsLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- checkTargetRegion(byte[], String, Object) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Checks whether the given regionName is either equal to our region, or that the regionName is
the primary region to our corresponding range for the secondary replica.
- checkTask(AsyncProcessTask<CResult>) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- checkTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
tells Coordination that it should check for new tasks
- checkTasks() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- checkTaskStillAvailable(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Check that the task is still there
- checkTaskStillAvailable(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- checkTempDir(Path, Configuration, FileSystem) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Make sure the hbase temp directory exists and is empty.
- checkThreadCount(int) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- checkTimeLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- checkTimeLimit(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- checkTimeout(String, int) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- checkTimestamps(Map<byte[], List<Cell>>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Check the collection of families for valid timestamps n * @param now current timestamp n
- checkTransformation(String) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
-
- checkTransition(RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- checkTransition(RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- checkTransition(RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- checkUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
-
- checkUnsupportedProcedure(Map<Class<?>, List<Procedure<?>>>) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
In HBASE-20811, we have introduced a new TRSP to assign/unassign/move regions, and it is
incompatible with the old AssignProcedure/UnassignProcedure/MoveRegionProcedure.
- checkUserPermission(UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Checks the given value for validity.
- checkVersion(byte, long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Check whether this version should be retained.
- checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersion(FileSystem, Path, boolean, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersions(Cell, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- checkVersions(Cell, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkWriteTableDistribution() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- checkZk() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Try to create a ZooKeeper connection.
- checkZooKeeper() - Method in interface org.apache.hadoop.hbase.tool.Canary
-
Runs Canary in Zookeeper mode.
- checkZooKeeper() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- CHGROUP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- childExps - Variable in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- childrenChangedFuture - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- childrenCountDown() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to notify that one of the sub-procedures has completed.
- childrenLatch - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- CHMOD - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- chooseSinks() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Refresh the list of sinks.
- chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationBarrierCleaner
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- chore() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- chore() - Method in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
- chore - Variable in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- chore() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.TimeoutMonitor
-
Deprecated.
- chore() - Method in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- chore() - Method in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.namequeues.SlowLogTableOpsChore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
- chore - Variable in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache.QuotaRefresherChore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- chore() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- chore - Variable in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTunerChore
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.CompactionChecker
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- chore() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl.ReplicationStatisticsChore
-
- chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
The task to execute on each scheduled execution of the Chore
- CHORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Configures the threadpool used for scanning the archive directory for the HFileCleaner If it is
an integer and >= 1, it would be the size; if 0.0 < size <= 1.0, size would be available
processors * size.
- CHORE_SERVICE_PREFIX - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- ChoreService - Class in org.apache.hadoop.hbase
-
ChoreService is a service that can be used to schedule instances of
ScheduledChore
to run
periodically while sharing threads.
- ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- ChoreService(String, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- ChoreService(String, int, boolean) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- choreService - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- choreService - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- choreService - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- choreService - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- choreService - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
ChoreService used to schedule tasks that we want to run periodically
- choreService - Variable in class org.apache.hadoop.hbase.ScheduledChore
-
Interface to the ChoreService that this ScheduledChore is scheduled with.
- choreService - Variable in class org.apache.hadoop.hbase.util.ConnectionCache
-
- ChoreService.ChoreServiceThreadFactory - Class in org.apache.hadoop.hbase
-
Custom ThreadFactory used with the ScheduledThreadPoolExecutor so that all the threads are
daemon threads, and thus, don't prevent the JVM from shutting down
- ChoreServiceThreadFactory(String) - Constructor for class org.apache.hadoop.hbase.ChoreService.ChoreServiceThreadFactory
-
- choresMissingStartTime - Variable in class org.apache.hadoop.hbase.ChoreService
-
Maps chores to Booleans which indicate whether or not a chore has caused an increase in the
core pool size of the ScheduledThreadPoolExecutor.
- chunk - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
The current chunk being written to
- chunk - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter.ReadyChunk
-
- Chunk - Class in org.apache.hadoop.hbase.regionserver
-
A chunk of memory out of which allocations are sliced.
- Chunk(int, int, ChunkCreator.ChunkType) - Constructor for class org.apache.hadoop.hbase.regionserver.Chunk
-
Create an uninitialized chunk.
- Chunk(int, int, ChunkCreator.ChunkType, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.Chunk
-
Create an uninitialized chunk.
- CHUNK_POOL_INITIALSIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- CHUNK_POOL_MAXSIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- CHUNK_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- CHUNK_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- chunkByteSize - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
The size of individual Bloom filter chunks to create
- chunkCount - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- ChunkCreator - Class in org.apache.hadoop.hbase.regionserver
-
Does the management of memstoreLAB chunk creations.
- ChunkCreator(int, boolean, long, float, float, HeapMemoryManager, float) - Constructor for class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- chunkCreator - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- ChunkCreator.ChunkType - Enum in org.apache.hadoop.hbase.regionserver
-
Types of chunks, based on their sizes
- ChunkCreator.MemStoreChunkPool - Class in org.apache.hadoop.hbase.regionserver
-
A pool of
Chunk
instances.
- ChunkCreator.MemStoreChunkPool.StatisticsThread - Class in org.apache.hadoop.hbase.regionserver
-
- chunkId - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter.ReadyChunk
-
- chunkID - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- chunkIdMap - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- chunkPoolDisabled - Static variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- chunks - Variable in class org.apache.hadoop.hbase.regionserver.CellChunkMap
-
- chunks - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- chunkSize - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- chunkSize - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- chunkType - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
- ChunkType() - Constructor for enum org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
-
- chunkType - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- CHUSER - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- cipher - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- cipher - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- Cipher - Class in org.apache.hadoop.hbase.io.crypto
-
A common interface for a cryptographic algorithm.
- Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
-
- cipher - Variable in class org.apache.hadoop.hbase.io.crypto.Context
-
- CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cipher for encryption
- CIPHER_CLASSES_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- CIPHER_JCE_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- CIPHER_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- cipherMode - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- cipherMode - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- cipherMode - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- cipherMode - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- cipherProvider - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
-
An CipherProvider contributes support for various cryptographic Ciphers.
- cipherProviderResults - Static variable in class org.apache.hadoop.hbase.util.EncryptionTest
-
- cipherResults - Static variable in class org.apache.hadoop.hbase.util.EncryptionTest
-
- claimQueue(ServerName, String, ServerName) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- claimQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- claimQueue(ServerName, String, ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Change ownership for the queue identified by queueId and belongs to a dead region server.
- claimQueue(ServerName, String, ServerName) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- claimReplicationQueue(ServerName, String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandler
-
- claimReplicationQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- ClaimReplicationQueueCallable - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ClaimReplicationQueueCallable() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ClaimReplicationQueueCallable
-
- ClaimReplicationQueueRemoteProcedure - Class in org.apache.hadoop.hbase.master.replication
-
- ClaimReplicationQueueRemoteProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- ClaimReplicationQueueRemoteProcedure(ServerName, String, ServerName) - Constructor for class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- claimReplicationQueues(ZKWatcher, ReplicationSourceManager) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- ClaimReplicationQueuesProcedure - Class in org.apache.hadoop.hbase.master.replication
-
Used to assign the replication queues of a dead server to other region servers.
- ClaimReplicationQueuesProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- ClaimReplicationQueuesProcedure(ServerName) - Constructor for class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- CLASS_LOADER - Static variable in class org.apache.hadoop.hbase.ipc.RemoteWithExtrasException.ClassLoaderHolder
-
- CLASS_PREFIX_EXEMPTIONS - Static variable in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
If the class being loaded starts with any of these strings, we will skip trying to load it from
the coprocessor jar and instead delegate directly to the parent ClassLoader.
- CLASS_TO_ENUM - Static variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- classes - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- Classes - Class in org.apache.hadoop.hbase.util
-
Utilities for class manipulation.
- Classes() - Constructor for class org.apache.hadoop.hbase.util.Classes
-
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- classloader - Variable in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- classLoader - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- ClassLoaderBase - Class in org.apache.hadoop.hbase.util
-
Base class loader that defines couple shared constants used by sub-classes.
- ClassLoaderBase(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Creates a DynamicClassLoader that can load classes dynamically from jar files under a specific
folder.
- ClassLoaderHolder() - Constructor for class org.apache.hadoop.hbase.ipc.RemoteWithExtrasException.ClassLoaderHolder
-
- classLoadersCache - Static variable in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
External class loaders cache keyed by external jar path.
- className - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- className - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- className - Variable in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- className - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- className - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- className - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- CLASSNAME_KEY - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Key to use setting non-default BufferedMutator implementation in Configuration.
- ClassSize - Class in org.apache.hadoop.hbase.util
-
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an
object of this class will occupy in memory The core of this class is taken from the Derby project
- ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
-
- ClassSize.MemoryLayout - Class in org.apache.hadoop.hbase.util
-
MemoryLayout abstracts details about the JVM object layout.
- ClassSize.UnsafeLayout - Class in org.apache.hadoop.hbase.util
-
UnsafeLayout uses Unsafe to guesstimate the object-layout related parameters like object header
sizes and oop sizes See HBASE-15950.
- ClassSize.UnsafeLayout.HeaderSize - Class in org.apache.hadoop.hbase.util
-
- clazz - Variable in enum org.apache.hadoop.hbase.io.hfile.BlockCacheFactory.ExternalBlockCaches
-
- clazz - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher.HBaseDatagramChannelFactory
-
- clazz - Variable in enum org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
-
- clazz - Variable in enum org.apache.hadoop.hbase.wal.RegionGroupingProvider.Strategies
-
- clazz - Variable in enum org.apache.hadoop.hbase.wal.WALFactory.Providers
-
- clean() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Free all direct buffers if allocated, mainly used for testing.
- cleanAllPreviousInstances(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- cleaner - Variable in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- CLEANER_INTERVAL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- CleanerChore<T extends FileCleanerDelegate> - Class in org.apache.hadoop.hbase.master.cleaner
-
Abstract Cleaner that uses a chain of delegates to clean a directory of files
- CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String, DirScanPool) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String, DirScanPool, Map<String, Object>, List<Path>) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- CleanerChore.Action<T> - Interface in org.apache.hadoop.hbase.master.cleaner
-
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Enable/Disable the cleaner chore.
- cleanerChoreSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the cleaner chore on/off.
- cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- cleanerChoreSwitch(boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- CleanerContext(FileStatus) - Constructor for class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- cleanerLatch - Variable in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- cleanerPoolSizeConfigDefault - Variable in enum org.apache.hadoop.hbase.master.cleaner.DirScanPool.Type
-
- cleanerPoolSizeConfigName - Variable in enum org.apache.hadoop.hbase.master.cleaner.DirScanPool.Type
-
- cleanersChain - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanerThreadCheckIntervalMsec - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- cleanerThreadTimeoutMsec - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- cleanerThreadTimeoutMsec - Variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- cleanExpiredMobFiles(String, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
-
Cleans the MOB files when they're expired and their min versions are 0.
- cleanExpiredMobFiles(FileSystem, Configuration, TableName, ColumnFamilyDescriptor, CacheConfig, long) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Cleans the expired mob files.
- cleanFileIfNeeded(FileStatus, HStore, AtomicLong, AtomicLong) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- cleanMergeRegion(RegionInfo, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
If merged region no longer holds reference to the merge regions, archive merge region on hdfs
and perform deleting references in hbase:meta
- cleanOldLogs() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Archive old logs.
- cleanOldLogs(String, boolean, String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Cleans a log file and all older logs from replication queue.
- cleanOldLogs(NavigableSet<String>, String, boolean, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- cleanOldServerName(ServerName, Iterator<ServerName>) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- cleanParent(MasterServices, RegionInfo, Result) - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- cleanParent(RegionInfo, Result) - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
If daughters no longer hold reference to the parents, delete the parent.
- cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Handles restart of a server.
- cleanRegionsInMeta(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
There may be items for this table still up in hbase:meta in the case where the info:regioninfo
column was empty because of some write error.
- cleanReplicationBarrier - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- cleanReplicationBarrier() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- cleanReplicationBarrierTable - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- cleanRestoreDir(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
clean restore directory after snapshot scan job
- cleanRestoreDir(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
clean restore directory after snapshot scan job
- cleanServerCache(ServerName, Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- cleanup() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- cleanup(IOException) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
Cleans the call not yet sent when we finish.
- cleanup() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
Cleanup after ourselves...
- cleanup() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Do the necessary cleanup after the call if needed.
- cleanup() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
-
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- cleanup(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- cleanup() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Explicitly mark this status as able to be cleaned up, even though it might not be complete.
- cleanup() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Cancel threads if they haven't finished.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Users should override this method.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- cleanup() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Will be called by the framework to give the store a chance to do some clean up works.
- cleanup() - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- cleanUp() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- cleanup(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cleanup after Throwable caught invoking method.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Cancel threads if they haven't finished.
- cleanup(String, Table) - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run cleanup tasks when the Chore encounters an error and must stop running
- cleanup(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- cleanup(Admin, Deque<LoadIncrementalHFiles.LoadQueueItem>, ExecutorService, SecureBulkLoadClient) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- CLEANUP_INTERVAL - Static variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- CLEANUP_INTERVAL - Static variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- cleanupAfterRollbackOneStep(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- cleanUpAndReportFailure(IOException) - Method in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- cleanupBulkLoad(Connection, String) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- cleanupBulkLoad(RpcController, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- cleanupBulkLoad(RpcController, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- cleanupBulkLoad(HRegion, ClientProtos.CleanupBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- cleanupCalls(IOException) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- cleanupCompletedRestoreInMap() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Remove the procedures that are marked as finished
- cleanupConnection() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- cleanupConnection() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- cleanupConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
Does the clean up work after the connection is removed from the connection pool
- cleanupDaughterRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Remove daughter region
- cleanupFailedOpen(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- cleanupHbckZnode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- cleanUpHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- cleanUpHFileRefs(WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- cleanupIdleConnections() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- cleanupIdleConnectionTask - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- cleanupMergedRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Clean up a merged region on rollback after failure.
- cleanupMergedRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Remove merged region
- cleanupObsoleteMobFiles(Configuration, TableName) - Method in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
Performs housekeeping file cleaning (called by MOB Cleaner chore)
- cleanUpOldNonces() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- cleanupOutstandingSyncsOnException(long, Exception) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- cleanupPool - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- cleanupPoolOnClose - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- cleanupPoolOnClose - Variable in class org.apache.hadoop.hbase.client.HTable
-
- cleanupReplicaReplicaStaleCache() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- cleanupSentinels() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Removes "abandoned" snapshot/restore requests.
- cleanupSentinels(Map<TableName, SnapshotSentinel>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Remove the sentinels that are marked as finished and the completion time has exceeded the
removal timeout.
- cleanupSplitDir(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- cleanupTempDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Clean up any temp detritus that may have been left around from previous operation attempts.
- clear() - Method in interface org.apache.hadoop.hbase.CellBuilder
-
Remove all internal elements from builder.
- clear() - Method in class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
-
- clear() - Method in class org.apache.hadoop.hbase.client.BatchErrors
-
- clear() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- clear() - Method in class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- clear() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- clear() - Method in class org.apache.hadoop.hbase.client.NoOpRetryingInterceptorContext
-
- clear() - Method in class org.apache.hadoop.hbase.client.RetryingCallerInterceptorContext
-
This function clears the internal state of the context object.
- clear() - Method in interface org.apache.hadoop.hbase.client.ScanResultCache
-
Clear the cached result if any.
- clear() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
These methods are unsupported, and no code using CompoundConfiguration depend upon them.
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- clear() - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- clear() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- clear() - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- clear() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- clear() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- clear() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- clear() - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
- clear() - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Flushes the dictionary, empties all values.
- clear() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- clear() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- clear() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- clear() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Called on stop of AssignmentManager.
- clear() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Atomically removes all of the elements from this queue.
- clear() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- clear(TNode, FairQueue<T>, AvlUtil.AvlKeyComparator<TNode>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- clear() - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
Removes all locks by clearing the maps.
- clear() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- clear() - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- clear() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Removes all the MetricRegisties.
- clear() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Clear current state of scheduler such that it is equivalent to newly created scheduler.
- clear() - Method in class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- clear() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- clear() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Removes all entries from the store.
- clear() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- clear() - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- clear() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- clear() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSource
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Removes all metrics about this Source.
- clear(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
Remove all the elements from the queue corresponding to walGroupId
- clear() - Method in class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- clear() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- clear() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- clear() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- clear() - Method in class org.apache.hadoop.hbase.util.SortedList
-
- clear(Configuration) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Delete the master znode if its content (ServerName string) is the same as the one in the znode
file.
- clear() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Resets the estimator, clearing out all previously inserted items
- clearAll() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- clearAndClose(List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
- clearAndClose(List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- clearArchive() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- clearAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- clearAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Deprecated.
- clearAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Removes given labels from user's globally authorized list of labels.
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- clearAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Removes given labels from user's globally authorized list of labels.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Clear all the blocks corresponding to this table from BlockCache.
- clearBlockCache(ServerName, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearBlockCache(ServerName, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearBlockCache(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- clearCache() - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- clearCache() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- clearCache() - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- clearCache() - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries.
- clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries of a server.
- clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries of a table.
- clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location, no matter what it is.
- clearCache(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location with specific replicaId.
- clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location for a table, row and server
- clearCache(RegionInfo) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Deletes the cached location of the region if necessary, based on some error from source.
- clearCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
- clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Clears the cache.
- clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Clears the cache.
- clearCache() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- clearCache(AuthManager.PermissionCache) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
- clearCache() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Clear any caches that pertain to server name sn
.
- clearCaches(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- clearChunkIds() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- clearChunksInPool() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- clearCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- clearCompactedfiles(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- clearCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Clears all the compacted files and returns them.
- clearCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear compacting queues on a regionserver.
- clearCompactionQueues(ServerName, Set<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear compacting queues on a region server.
- clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearCompactionQueues - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- clearCompactionQueues(RpcController, AdminProtos.ClearCompactionQueuesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- clearCompactionQueues(ServerName, Set<String>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- clearCompletedRequests(RegionLocations) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- clearCurrentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clear dead region servers from master.
- clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- clearDeadServers(RpcController, MasterProtos.ClearDeadServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- clearDeadServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- clearDeadServersWithSameHostNameAndPortOfOnlineServer() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
To clear any dead server with same host name and port of any online server
- clearDisableFlag() - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- clearFiles() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- clearFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Clears all the files currently in use and returns them.
- clearFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- clearFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- clearHashCache() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- clearJmxCache() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
-
For JMX to forget about all previously exported metrics.
- clearLongCompactionsQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- clearMasterStubCache(MasterProtos.MasterService.Interface) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- clearMasterStubCacheOnError(MasterProtos.MasterService.Interface, Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
-
- clearMessage() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- clearMetricIfNotNull(MutableGaugeLong) - Static method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- clearMetrics() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- clearNamedQueue() - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- clearNamedQueue(NamedQueuePayload.NamedQueueEvent) - Method in class org.apache.hadoop.hbase.namequeues.LogEventHandler
-
Cleans up queues maintained by services.
- clearNamedQueue(NamedQueuePayload.NamedQueueEvent) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
clears queue records from ringbuffer
- clearNamedQueue() - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Cleans up queues maintained by services.
- clearProgress() - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- clearProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Clear away any progress that has been made so far.
- clearQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- clearRegionBlockCache(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- clearRegionBlockCache(RpcController, AdminProtos.ClearRegionBlockCacheRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Allows flushing the region cache of all locations that pertain to tableName
- clearRegionCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- clearRegionCache(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Clear all the entries in the region location cache, for all the tables.
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- clearRegionLocationCache() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Clear all the entries in the region location cache.
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- clearRegionLocationCache() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- clearRemainingLine() - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- clearReplicationScope() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- clearShortCompactionsQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Clears online slow/large RPC logs from the provided list of RegionServers
- clearSlowLogResponses(Set<ServerName>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Clears online slow RPC logs from the provided list of RegionServers
- clearSlowLogResponses(Set<ServerName>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- clearSlowLogResponses(Set<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearSlowLogResponses(Set<ServerName>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearSlowLogResponses(Set<ServerName>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- clearSlowLogResponses(Set<TServerName>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- clearSlowLogsResponses(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- clearSlowLogsResponses(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- clearSlowLogsResponses(RpcController, AdminProtos.ClearSlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- clearSnapshot(long) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
This method is protected under HStore write lock.
The passed snapshot was successfully persisted; it can be let go.
- clearSnapshot(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Clears the current snapshot of the Memstore.
- clearState() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Clear the current state of hbck.
- clearStub() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- clearTables() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Remove the currently archived tables.
- clearTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- clearThreadLocals() - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- clearWALEntryBatch() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
Attempts to properly update ReplicationSourceManager.totalBufferUser
, in case
there were unprocessed entries batched by the reader to the shipper, but the shipper didn't
manage to ship those because the replication source is being terminated.
- clearZKExceptionMetrics() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- CLI(Configuration) - Constructor for class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- ClickjackingPreventionFilter - Class in org.apache.hadoop.hbase.http
-
- ClickjackingPreventionFilter() - Constructor for class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
-
- client - Variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- client - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- client - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.CancelOnClose
-
- client - Variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- Client - Class in org.apache.hadoop.hbase.rest.client
-
A wrapper around HttpClient which provides some useful function and semantics for interacting
with the REST gateway.
- Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Default Constructor
- Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor, allowing to define custom trust store (only for SSL connections)
- Client(Cluster, Configuration, String, Optional<String>, Optional<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor, allowing to define custom trust store (only for SSL connections)
- client - Variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.ClientConnnection
-
- client - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- client - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- Client.ClientTrustStoreInitializationException - Exception in org.apache.hadoop.hbase.rest.client
-
- CLIENT_BOOTSTRAP_NODE_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- CLIENT_CONNECTION_REGISTRY_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Registry implementation to be used on the client side.
- CLIENT_FINALIZER_DATA_METHOD - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- CLIENT_KEYTAB_KERBEROS_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication.JaasConfiguration
-
- CLIENT_NONCES_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.client.NonceGenerator
-
- CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The ZK client port key in the ZK properties map.
- CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- CLIENT_SIDE_METRICS_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
Set this key to true
to enable metrics collection of client requests.
- CLIENT_SVC - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- CLIENT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Client port of ZooKeeper for client to locate meta
- CLIENT_ZOOKEEPER_OBSERVER_MODE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Indicate whether the client ZK are observer nodes of the server ZK
- CLIENT_ZOOKEEPER_QUORUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of ZooKeeper quorum configuration parameter for client to locate meta.
- clientAckTime - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- clientAddress - Variable in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- clientAddress - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- clientAddress - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- clientAddress - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- clientAddress - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- ClientAsyncPrefetchScanner - Class in org.apache.hadoop.hbase.client
-
ClientAsyncPrefetchScanner implements async scanner behaviour.
- ClientAsyncPrefetchScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- ClientAsyncPrefetchScanner.PrefetchRunnable - Class in org.apache.hadoop.hbase.client
-
- ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
-
Configurable policy for the amount of time a client should wait for a new request to the server
when given the server load statistics.
- ClientBackoffPolicyFactory - Class in org.apache.hadoop.hbase.client.backoff
-
- ClientBackoffPolicyFactory() - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
-
- ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
-
Default backoff policy that doesn't create any backoff for the client, regardless of load
- clientBuilder - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- clientChannelClass - Variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- clientChannelClass() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- ClientConnnection(TTransport) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.ClientConnnection
-
Default constructor.
- ClientCoprocessorRpcController - Class in org.apache.hadoop.hbase.client
-
Client side rpc controller for coprocessor implementation.
- ClientCoprocessorRpcController() - Constructor for class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- ClientExceptionsUtil - Class in org.apache.hadoop.hbase.exceptions
-
- ClientExceptionsUtil() - Constructor for class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- clientId - Variable in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- ClientIdGenerator - Class in org.apache.hadoop.hbase.client
-
The class that is able to determine some unique strings for the client, such as an IP address,
PID, and composite deterministic ID.
- ClientIdGenerator() - Constructor for class org.apache.hadoop.hbase.client.ClientIdGenerator
-
- clientIPAndPort - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- clientMetricRegisterAndMark() - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- ClientMetricsImpl(String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- ClientMetricsImpl(String, long, long, long) - Constructor for class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- clientMetricsLossyCounting - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- clientMetricsMap - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- clientMetricsMap - Variable in class org.apache.hadoop.hbase.UserMetricsBuilder
-
- clientMetricsMap - Variable in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- ClientModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
- ClientModeStrategy() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- clientModeStrategy - Variable in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
-
- clientName - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- clientPort - Variable in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
-
- clientPortList - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- clientRequestMeterName(String) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- ClientScanner - Class in org.apache.hadoop.hbase.client
-
Implements the scanner interface for the HBase client.
- ClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Create a new ClientScanner for the specified table Note that the passed
Scan
's start
row maybe changed changed.
- clientScannerAsyncPrefetch - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- ClientServiceBlockingInterfaceWrapper(ClientProtos.ClientService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- ClientServiceCallable<T> - Class in org.apache.hadoop.hbase.client
-
A RegionServerCallable set to use the Client protocol.
- ClientServiceCallable(Connection, TableName, byte[], RpcController, int) - Constructor for class org.apache.hadoop.hbase.client.ClientServiceCallable
-
- ClientSideRegionScanner - Class in org.apache.hadoop.hbase.client
-
A client scanner for a region opened for read-only on the client side.
- ClientSideRegionScanner(Configuration, FileSystem, Path, TableDescriptor, RegionInfo, Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- ClientSimpleScanner - Class in org.apache.hadoop.hbase.client
-
ClientSimpleScanner implements a sync scanner behaviour.
- ClientSimpleScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSimpleScanner
-
- ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
Class to help with dealing with a snapshot description on the client side.
- ClientSnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
- ClientTokenUtil - Class in org.apache.hadoop.hbase.security.token
-
Utility methods for obtaining authentication tokens, that do not require hbase-server.
- ClientTokenUtil() - Constructor for class org.apache.hadoop.hbase.security.token.ClientTokenUtil
-
- ClientTrustStoreInitializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.rest.client.Client.ClientTrustStoreInitializationException
-
- ClientUtil - Class in org.apache.hadoop.hbase.client
-
- ClientUtil() - Constructor for class org.apache.hadoop.hbase.client.ClientUtil
-
- ClientUtils - Class in org.apache.hadoop.hbase.util
-
Common Utility class for clients
- ClientUtils() - Constructor for class org.apache.hadoop.hbase.util.ClientUtils
-
- ClientZKSyncer - Class in org.apache.hadoop.hbase.master.zksyncer
-
Tracks the target znode(s) on server ZK cluster and synchronize them to client ZK cluster if
changed
The target znode(s) is given through
ClientZKSyncer.getPathsToWatch()
method
- ClientZKSyncer(ZKWatcher, ZKWatcher, Server) - Constructor for class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- ClientZKSyncer.ClientZkUpdater - Class in org.apache.hadoop.hbase.master.zksyncer
-
Thread to synchronize znode data to client ZK cluster
- ClientZKSyncer.ZKData - Class in org.apache.hadoop.hbase.master.zksyncer
-
Used to store the newest data which we want to sync to client zk.
- ClientZkUpdater(String, ClientZKSyncer.ZKData) - Constructor for class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer.ClientZkUpdater
-
- clientZkWatcher - Variable in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server clock skew is too high.
- ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
-
- clone() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- clone() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
Implement Cloneable interface
- clone() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue
-
Clones a KeyValue.
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
- clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- clone() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Public exposure of Object.clone() in order to allow clients to easily capture current state.
- clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneHdfsMobRegion(Map<String, SnapshotProtos.SnapshotRegionManifest>, RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Clone the mob region.
- cloneHdfsRegions(ThreadPoolExecutor, Map<String, SnapshotProtos.SnapshotRegionManifest>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Clone specified regions.
- cloneIfNecessary(ArrayList<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneIfNecessary(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneOnDiskBufferWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Clones the header followed by the on-disk (compressed/encoded/encrypted) data.
- cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneRegion(RegionInfo, Path, RegionInfo, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Clone region directory content from the snapshot info.
- cloneRegion(HRegion, RegionInfo, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Clone region directory content from the snapshot info.
- cloneRegionInfo(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
RegionInfo
from the snapshot region info.
- cloneRegionInfo(TableName, RegionInfo) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
get individual arrays for tests
- cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- cloneSnapshot(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- cloneSnapshot(SnapshotProtos.SnapshotDescription, TableName, SnapshotProtos.SnapshotDescription, TableDescriptor, NonceKey, boolean, String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Clone the specified snapshot.
- cloneSnapshot(SnapshotProtos.SnapshotDescription, TableDescriptor, NonceKey, boolean, String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Clone the specified snapshot into a new table.
- cloneSnapshotAsync(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content, but does not block and wait for it to be
completely cloned.
- cloneSnapshotAsync(String, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshotAsync(String, TableName, boolean, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshotAsync(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneSnapshotAsync(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- CloneSnapshotProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- CloneSnapshotProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Constructor (for failover)
- CloneSnapshotProcedure(MasterProcedureEnv, TableDescriptor, SnapshotProtos.SnapshotDescription) - Constructor for class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- CloneSnapshotProcedure(MasterProcedureEnv, TableDescriptor, SnapshotProtos.SnapshotDescription, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Constructor
- CloneSnapshotProcedure(MasterProcedureEnv, TableDescriptor, SnapshotProtos.SnapshotDescription, boolean, String) - Constructor for class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new table by cloning the existent table schema.
- cloneTableSchema(TableName, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- cloneTableSchema(TableName, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- cloneTableSchema(TableName, TableName, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- cloneTableSchema(TableName, TableName, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- cloneTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneTags() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- cloneTags(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- cloneTags() - Method in interface org.apache.hadoop.hbase.RawCell
-
Allows cloning the tags in the cell to a new byte[]
- cloneUncompressedBufferWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Clones the header followed by the uncompressed data, even if using compression.
- cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneValue(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Returns tag value in a new byte array.
- close() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
close any outside readers of the file n
- close() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- close() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileableStoreFile
-
- close() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- close() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- close() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- close() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- close() - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- close() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- close() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- close() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- close() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener
-
- close() - Method in interface org.apache.hadoop.hbase.client.ClusterStatusListener.Listener
-
Called to close the resources, if any.
- close() - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener
-
- close() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- close() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- close() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Closes this instance and releases any system resources associated with it
- close() - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- close() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
- close() - Method in class org.apache.hadoop.hbase.client.HTable
-
- close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- close() - Method in interface org.apache.hadoop.hbase.client.MasterKeepAliveConnection
-
- close() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- close() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- close() - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- close() - Method in interface org.apache.hadoop.hbase.client.Table
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- close() - Method in class org.apache.hadoop.hbase.coprocessor.example.DelegatingInternalScanner
-
- close() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Close this filesystem object
- close() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- close() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- close() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- close() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Close the file.
- close() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
End the current block and complete file at namenode.
- close() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Releases the compressor this writer uses to compress blocks into the compressor pool.
- close() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Releases the resources used.
- close() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
CloseClose stream(s) if necessary.
- close() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Close method with optional evictOnClose
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePreadReader
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- close() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Close this HFile scanner and do necessary cleanup.
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileStreamReader
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- close() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- close() - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Stop all threads related to this client.
- close(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper
-
- close(Closeable...) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
Deprecated.
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordWriter
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationDeserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationSerializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.Result94Deserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultDeserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultSerializer
-
- close(Closeable...) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Closes the writer, in this case flush table commits.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- close() - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- close() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser.Results
-
- close() - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- close(boolean) - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- close() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- close() - Method in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- close() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
Decreases the reference of the underlying reader for the mob file.
- close() - Method in class org.apache.hadoop.hbase.mob.MobCell
-
- close() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Closes the underlying reader, but do no evict blocks belonging to this file.
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Shutdown the thread pools and release rpc resources n
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Best effort attempt to close the threadpool via Thread.interrupt.
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- close() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- close() - Method in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
-
- close() - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- close() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Cleanup method on operation completion
- close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Closing a segment before it is being discarded
- close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- close() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Close all the readers We don't need to worry about subsequent requests because the Region holds
a write lock that will prevent any more reads or writes.
- close() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
-
Closes the scanner and releases any resources it has allocated n
- close() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Close the KeyValue scanner.
- close() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Shut down this Leases instance.
- close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Close instance since it won't be used any more, try to put the chunks back to pool
- close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Close this instance since it won't be used any more, try to put the chunks back to pool
- close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Close the region's metrics as this region is closing.
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Close the table's metrics as all the region are closing.
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Closing a segment before it is being discarded
- close() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Close the KeyValue scanner.
- close() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter.OutputStreamWrapper
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- close() - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- close() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- close() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- close() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- close() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- close() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- close() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- close() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- close() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- close() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
Close the open connections and shutdown the batchpool
- close() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- close() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- close() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- close() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- close() - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- close() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- close() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Caller no longer needs any edits from this WAL.
- close() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Shutdown all WALs and clean up any underlying storage.
- close() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
shutdown utstanding WALs and clean up any persisted state.
- CLOSE - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Close the connection to ZooKeeper.
- CLOSE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- CLOSE_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- CLOSE_PARAN_NODE - Static variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- CLOSE_WAIT_ABORT - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CLOSE_WAIT_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CLOSE_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Shuts down this lease instance when all outstanding leases expire.
- closeAll() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- closeAllRegionServerThreads(List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- closeAllScanners() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- closeAndArchiveCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Closes and archives the compacted files under this store
- closeAndWait(long) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Shutdown the threadpool, and wait for upto timeoutMs millis before bailing
- closeBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- closeBulkRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Closes the lock.
- closeCallBack - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- CloseChecker - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Check periodically to see if a system stop is requested
- CloseChecker(Configuration, long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
- closeCheckSizeLimit - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
- closeCheckTimeLimit - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
- closeCompletionService - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
- closeConn() - Method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- closeConn(IOException) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- closeConnection(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- closeCurrentConnection(SelectionKey, Throwable) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- closeCurrentLogStream(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- closed - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- closed - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- closed - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- closed - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- closed - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- closed - Variable in class org.apache.hadoop.hbase.client.HTable
-
- closed - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- closed - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- closed - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- closed - Variable in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- closed - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- closed - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- closed - Variable in class org.apache.hadoop.hbase.util.ConnectionCache.ConnectionInfo
-
- closed - Variable in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- closed - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- closed(IOException) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.Task
-
- closed(IOException) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.ZKTask
-
- CLOSED_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- closeDataNodeChannelsAndAwait() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- closeDeleteFamilyBloomFilter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- closedRegions - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- closedRegions - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- closedScanners - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- closeErrorCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- closeErrorsTolerated - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Number of log close errors tolerated before we abort
- closeExcessReplicasIfNeeded(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- closeExecutor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- closeExecutor - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- closeFile(MobFile) - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Closes a mob file.
- closeFileChannels() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- closeGeneralBloomFilter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- closeIdle(boolean) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- closeInternal() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- closeInternal() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
-
- closeInternal() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
- closeInternal() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- closeLock - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeLock - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- closeMaster() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Immediate close of the shared master.
- closeMasterService(ConnectionImplementation.MasterServiceState) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of the meta region on a region server.
- CloseMetaHandler(Server, RegionServerServices, RegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
-
- closeMetaTableRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Close meta region if we carry it
- closeMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- closeMSLABs() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
It is straight forward to close the output, do not need to write trailer like the Writer.close
- closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- closeOutputIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
True if we opened the outputStream
(and so will close it).
- closeProcId - Variable in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- closeProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- closeReader() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- closeReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- closeRecoveredEditsWriter(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter, List<IOException>) - Method in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
-
- closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- closeRegion(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- closeRegion(boolean) - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- closeRegion(String, boolean, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Close asynchronously a region, can be called from the master or internally by the regionserver
when stopping.
- closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Close a region on the region server.
- closeRegion - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
Set if this is a meta edit and it is of close region type.
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- closeRegion(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Attempts to undeploy a region from a region server based in information in META.
- CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of a region on a region server.
- CloseRegionHandler(Server, RegionServerServices, RegionInfo, boolean, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
This method used internally by the RegionServer to close out regions.
- CloseRegionHandler(Server, RegionServerServices, RegionInfo, boolean, EventType, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- closeRegionIgnoreErrors(RegionInfo, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Try to close the region, logs a warning on failure but continues.
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- closeRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Closes the region operation lock.
- closeRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Closes the region operation lock.
- CloseRegionProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
The remote procedure used to close a region.
- CloseRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- CloseRegionProcedure(TransitRegionStateProcedure, RegionInfo, ServerName, ServerName) - Constructor for class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- closeRegionSilently(ServerName, byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Close regionName
on sn
silently and immediately without using a
Procedure or going via hbase:meta.
- closeRegionSilentlyAndWait(ClusterConnection, ServerName, RegionInfo, long) - Static method in class org.apache.hadoop.hbase.master.ServerManager
-
Contacts a region server and waits up to timeout ms to close the region.
- closeRegionSilentlyAndWait(Connection, ServerName, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close
the region.
- closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- closeScanner() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- closeScanner() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- closeScanner(HRegion, RegionScanner, String, RpcCallContext) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- closeScannerIfExhausted(boolean) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- closeSocket() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- closeSrcFs() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- closeStoreFile(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- closeStreams() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Closes the backing streams
- closeStreams() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- closestRowBefore - Variable in class org.apache.hadoop.hbase.client.Get
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- closeTable(Table) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- closeTable(Table) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- closeThreadPool - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
Used when close this output sink.
- closeUserRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Schedule closes on all user regions.
- closeWithoutLock() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- closeWriter(WALProvider.AsyncWriter, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- closeWriter(WALProvider.Writer, Path, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- closeWriters() - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
Close all of the output streams.
- closeZk() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- closing - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closing - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- cluster - Variable in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- cluster - Variable in class org.apache.hadoop.hbase.rest.client.Client
-
- Cluster - Class in org.apache.hadoop.hbase.rest.client
-
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example
multiple redundant web service gateways.
- Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is in distributed mode or not
- CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster ID
- CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of the file for unique cluster ID
- CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- CLUSTER_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- ClusterCompactionQueues - Class in org.apache.hadoop.hbase.util.compaction
-
- ClusterCompactionQueues(int) - Constructor for class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- clusterCompactionQueues - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- ClusterConnection - Interface in org.apache.hadoop.hbase.client
-
Internal methods on Connection that should not be used by user code.
- clusterConnection - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cluster connection to be shared by services.
- clusterHasActiveMaster - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- clusterId - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- ClusterId - Class in org.apache.hadoop.hbase
-
The identifier for this cluster.
- ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
-
New ClusterID.
- ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
-
- clusterId - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- clusterId - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- clusterId - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- clusterId - Variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- clusterId - Variable in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- clusterId - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- clusterId - Variable in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- clusterId - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Unique identifier for the cluster we are a part of.
- clusterId - Variable in class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
-
- clusterId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- clusterId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- clusterId - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- clusterId - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- clusterIds - Variable in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- clusterIds - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- clusterIds - Variable in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
The first element in the list is the cluster id on which the change has originated
- clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- clusterKey - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- clusterKey - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- ClusterLoadState - Class in org.apache.hadoop.hbase.master.balancer
-
Class used to hold the current state of the cluster and how balanced it is.
- ClusterLoadState(Map<ServerName, List<RegionInfo>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- ClusterMarkingEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Filters out entries with our peerClusterId (i.e.
- ClusterMarkingEntryFilter(UUID, UUID, ReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
-
- ClusterMetrics - Interface in org.apache.hadoop.hbase
-
Metrics information on the HBase cluster.
- ClusterMetrics - Class in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model
-
- ClusterMetrics(String, String, ServerName, List<ServerName>) - Constructor for class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- ClusterMetrics.Option - Enum in org.apache.hadoop.hbase
-
Kinds of ClusterMetrics
- ClusterMetricsBuilder - Class in org.apache.hadoop.hbase
-
- ClusterMetricsBuilder() - Constructor for class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- ClusterMetricsBuilder.ClusterMetricsImpl - Class in org.apache.hadoop.hbase
-
- ClusterMetricsEncoder(InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher.ClusterMetricsEncoder
-
- ClusterMetricsImpl(String, List<ServerName>, List<ServerName>, Map<ServerName, ServerMetrics>, ServerName, List<ServerName>, List<RegionState>, String, List<String>, Boolean, int, List<ServerName>, Map<TableName, RegionStatesCount>, List<ServerTask>) - Constructor for class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- ClusterMetricsResource - Class in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
-
- ClusterMetricsResource(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- clusterRequestsCounter - Variable in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- ClusterSchema - Interface in org.apache.hadoop.hbase.master
-
View and edit the current cluster schema.
- ClusterSchemaService - Interface in org.apache.hadoop.hbase.master
-
Mixes in ClusterSchema and Service
- clusterSchemaService - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ClusterSchemaServiceImpl - Class in org.apache.hadoop.hbase.master
-
- ClusterSchemaServiceImpl(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- clusterShutDown - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- clusterShutdown - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- clusterState - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- clusterState - Variable in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- ClusterStatus - Class in org.apache.hadoop.hbase
-
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, List<RegionState>, String[], Boolean, int) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- ClusterStatus(ClusterMetrics) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- clusterStatus - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- ClusterStatusChore - Class in org.apache.hadoop.hbase.master.balancer
-
Chore that will feed the balancer the cluster status.
- ClusterStatusChore(HMaster, LoadBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- clusterStatusChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ClusterStatusHandler() - Constructor for class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener.ClusterStatusHandler
-
- clusterStatusListener - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- ClusterStatusListener - Class in org.apache.hadoop.hbase.client
-
A class that receives the cluster status, and provide it as a set of service to the client.
- ClusterStatusListener(ClusterStatusListener.DeadServerHandler, Configuration, Class<? extends ClusterStatusListener.Listener>) - Constructor for class org.apache.hadoop.hbase.client.ClusterStatusListener
-
- clusterStatusListener - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- ClusterStatusListener.DeadServerHandler - Interface in org.apache.hadoop.hbase.client
-
Class to be extended to manage a new dead server.
- ClusterStatusListener.Listener - Interface in org.apache.hadoop.hbase.client
-
The interface to be implemented by a listener of a cluster status event.
- ClusterStatusListener.MulticastListener - Class in org.apache.hadoop.hbase.client
-
An implementation using a multicast message between the master & the client.
- ClusterStatusListener.MulticastListener.ClusterStatusHandler - Class in org.apache.hadoop.hbase.client
-
Class, conforming to the Netty framework, that manages the message received.
- ClusterStatusPublisher - Class in org.apache.hadoop.hbase.master
-
Class to publish the cluster status to the client.
- ClusterStatusPublisher(HMaster, Configuration, Class<? extends ClusterStatusPublisher.Publisher>) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher.MulticastPublisher - Class in org.apache.hadoop.hbase.master
-
- ClusterStatusPublisher.MulticastPublisher.ClusterMetricsEncoder - Class in org.apache.hadoop.hbase.master
-
- ClusterStatusPublisher.MulticastPublisher.HBaseDatagramChannelFactory<T extends org.apache.hbase.thirdparty.io.netty.channel.Channel> - Class in org.apache.hadoop.hbase.master
-
- ClusterStatusPublisher.Publisher - Interface in org.apache.hadoop.hbase.master
-
- clusterStatusPublisherChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- clusterStatusToRegionDetails() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- clusterStatusTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracker on cluster settings up in zookeeper.
- ClusterStatusTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Creates a cluster status tracker.
- cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Returns the adjusted trichotomous value according to the ordering imposed by this
Order
.
- CNT_BASE - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- COALESCE_INC_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- coalescer - Variable in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- code - Variable in enum org.apache.hadoop.hbase.Cell.Type
-
- code - Variable in enum org.apache.hadoop.hbase.executor.EventType
-
- code - Variable in enum org.apache.hadoop.hbase.KeyValue.Type
-
- code - Variable in enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
-
- code - Variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- code - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- code - Variable in class org.apache.hadoop.hbase.rest.client.Response
-
- code - Variable in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- code - Variable in enum org.apache.hadoop.hbase.security.access.Permission.Scope
-
- code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Scope
-
- code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
The code for this method.
- code - Variable in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
- code - Variable in enum org.apache.hadoop.hbase.util.ChecksumType
-
- CODE_ARRAY - Static variable in enum org.apache.hadoop.hbase.Cell.Type
-
- codeArray - Static variable in enum org.apache.hadoop.hbase.KeyValue.Type
-
- Codec - Interface in org.apache.hadoop.hbase.codec
-
Encoder/Decoder for Cell.
- codec - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- codec - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- codec - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- codec - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
Codec the client asked use.
- Codec.Decoder - Interface in org.apache.hadoop.hbase.codec
-
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner
runs off the end of the cell block.
- Codec.Encoder - Interface in org.apache.hadoop.hbase.codec
-
Call flush when done.
- codecClsName - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- CodecException - Exception in org.apache.hadoop.hbase.codec
-
Thrown when problems in the codec whether setup or context.
- CodecException() - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- codelInterval - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- codelTargetDelay - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Cannot rely on enum ordinals .
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Cannot rely on enum ordinals .
- coefficient - Variable in class org.apache.hadoop.hbase.util.WeightedMovingAverage
-
- colAdjust - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- colBuff - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Thrift ColumnDescriptor "struct" based on an Hbase
HColumnDescriptor object.
- colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Hbase HColumnDescriptor object based on a Thrift
ColumnDescriptor "struct".
- coldWindowStoragePolicy - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- colFamTimeRangeMap - Variable in class org.apache.hadoop.hbase.client.Query
-
- colInverse - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- collect(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- CollectAllVisitor() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor.CollectAllVisitor
-
- collectFamilies(List<Cell>) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- CollectingVisitor() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
-
- CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
-
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
- CollectionBackedScanner(SortedSet<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(SortedSet<Cell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(CellComparator, Cell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionUtils - Class in org.apache.hadoop.hbase.util
-
- CollectionUtils() - Constructor for class org.apache.hadoop.hbase.util.CollectionUtils
-
Deprecated.
- collectRow() - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- collectStackId(ProcedureTree.Entry, Map<Integer, List<ProcedureTree.Entry>>, MutableInt) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- colLength - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- colocatedReplicaCountsPerGroup - Variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaHostCostFunction
-
- colocatedReplicaCountsPerHost - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- colocatedReplicaCountsPerRack - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- colocatedReplicaCountsPerServer - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- colOffset - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- Color - Enum in org.apache.hadoop.hbase.hbtop.terminal
-
Terminal color definitions.
- Color() - Constructor for enum org.apache.hadoop.hbase.hbtop.terminal.Color
-
- color(Color, Color, boolean, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- cols - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- cols - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- colsCovered - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- colTransform - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- Column(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint.Column
-
- column - Variable in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
-
- column - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- column - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- column - Variable in class org.apache.hadoop.hbase.rest.model.CellModel
-
- column - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- COLUMN_DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COLUMN_DIVIDER - Static variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Colon character in UTF-8
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
space delimited list of columns
- columnCell - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- ColumnCount - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Simple wrapper for a byte buffer and a counter.
- ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Constructor
- ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Constructor
- ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Constuctor
- ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
-
Simple filter that returns first N columns on row only.
- ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- columnFamily - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- ColumnFamilyDescriptor - Interface in org.apache.hadoop.hbase.client
-
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
- ColumnFamilyDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- ColumnFamilyDescriptorBuilder(byte[]) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- ColumnFamilyDescriptorBuilder(ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor - Class in org.apache.hadoop.hbase.client
-
An ModifyableFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
- columnFamilyDescriptorFromHBase(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- columnFamilyDescriptorFromThrift(TColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- columnFound - Variable in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- columnIndex - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
-
Defines how value for specific column is interpreted and provides utility methods like compare,
add, multiply etc for them.
- ColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- columnOffset - Variable in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
-
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
- ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with an integer offset and limit.
- ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with a string/bookmark based offset and limit.
- ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches a particular prefix.
- ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that are between minColumn to
maxColumn.
- ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Create a filter to select those keys with columns that are between minColumn and maxColumn.
- columns - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- columns - Variable in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
-
- columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The grouping columns.
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- columns - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
Contains the list of columns that the ExplicitColumnTracker is tracking.
- columns - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- columns - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Keeps track of columns and versions
- columns - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- columns - Variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- columns - Variable in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- columns - Variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- columnsAdded - Variable in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- ColumnSchemaModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a column family schema.
- ColumnSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Default constructor
- columnsDeleted - Variable in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- columnsModified - Variable in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver.querymatcher
-
Implementing classes of this interface will be used for the tracking and enforcement of columns
and numbers of versions and timeToLive during the course of a Get or Scan operation.
- ColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- ColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- combine() - Method in class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- combine(Record) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- CombinedBlockCache(FirstLevelBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- CombinedBlockCache.CombinedCacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
- combinedCacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- CombinedCacheStats(CacheStats, CacheStats) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- combineTableNameSuffix(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- comConf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- comConf - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a comma
- COMMA - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- COMMA - Static variable in class org.apache.hadoop.hbase.util.JSONBean
-
- COMMAND_DESCRIPTION_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- COMMAND_DESCRIPTIONS - Static variable in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
-
- CommandDescription - Class in org.apache.hadoop.hbase.hbtop.screen.help
-
Represents a description of a command that we can execute in the top screen.
- CommandDescription(String, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
-
- CommandDescription(List<String>, String) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
-
- commit(MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- commit(MonitoredTask) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Commit the flush - add the store file to the store and clear the memstore snapshot.
- commitDaughterRegion(RegionInfo, List<Path>, MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Commit a daughter region, moving it from the split temporary directory to the proper location
in the filesystem.
- commitFile(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Commits the mob file.
- commitMergedRegion(List<Path>, MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Commit a merged region, making it ready for use.
- commitOrAbortMobWriter(StoreFileWriter, long, long, boolean) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- commitStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Move the file from a build/temp location to the main family store directory.
- commitStoreFile(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- commitStoreFiles(List<Path>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Commit the given files
.
- commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- committedFiles - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- committedFiles - Variable in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- commitWriter(StoreFileWriter, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- commitWriter(T, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- commitWriter(DateTieredMultiFileWriter, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactor
-
- commitWriter(StoreFileWriter, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
- commitWriter(StripeMultiFileWriter, Compactor.FileDetails, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- commitWriters(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Commit all writers.
- commitWriters(long, boolean, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
- COMMON_DIRECTORY_PERMISSION - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- COMMON_DIRECTORY_PERMISSION_DEFAULT - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- CommonFSUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the underlying file system.
- CommonFSUtils() - Constructor for class org.apache.hadoop.hbase.util.CommonFSUtils
-
- CommonFSUtils.DfsBuilderUtility - Class in org.apache.hadoop.hbase.util
-
- CommonFSUtils.StreamLacksCapabilityException - Exception in org.apache.hadoop.hbase.util
-
Helper exception for those cases where the place where we need to check a stream capability is
not where we have the needed context to explain the impact and mitigation for a lack.
- CommonsCryptoAES - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- CommonsCryptoAES(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- CommonsCryptoAESDecryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- CommonsCryptoAESDecryptor(String, Properties) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- CommonsCryptoAESEncryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- CommonsCryptoAESEncryptor(String, Properties, SecureRandom) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a table.
- compact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table.
- compact(TableName, byte[], boolean, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- compact(AdminProtos.AdminService.BlockingInterface, RegionInfo, boolean, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table.
- compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compact(TableName, byte[], boolean, CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Compact column family of a table, Asynchronous operation even if CompletableFuture.get()
- compact(ServerName, RegionInfo, boolean, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Compact the region at specific region server.
- compact() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- compact(CompactionRequestImpl, ThroughputController, User) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- compact(ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- compact(CompactionRequestImpl, Compactor.InternalScannerFactory, Compactor.CellSinkFactory<T>, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- compact(CompactionRequestImpl, List<Long>, Map<Long, String>, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactor
-
- compact(CompactionRequestImpl, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
Do a minor/major compaction on an explicit set of storefiles from a Store.
- compact(CompactionRequestImpl, List<byte[]>, byte[], byte[], ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequestImpl, int, long, byte[], byte[], byte[], byte[], ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(Path, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
Execute the compaction on the specified path.
- compact(ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine.DateTieredCompactionContext
-
- compact(ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine.DefaultCompactionContext
-
- compact(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Synchronously compact all stores in the region.
- compact(CompactionContext, HStore, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Called by compaction thread and after region is opened to compact the HStores if necessary.
- compact(CompactionContext, HStore, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Compact the StoreFiles.
- compact(VersionedSegmentsList, String) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- compact(ThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine.StripeCompaction
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- compact(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- Compact(ServerName, MajorCompactionRequest) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- COMPACT_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- COMPACT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- COMPACT_MIN_KEY - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- COMPACT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- compactAllRegions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- compactAndWait(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- compactBloom() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- compactBloom() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Compact the Bloom filter before writing metadata & data to disk.
- COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- compacted - Variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- compactedAway - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- compactedCellCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- compactedCellCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- compactedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- compactedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- compactedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- compactedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- compactedFileDischarger - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactedfiles - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
List of compacted files inside this store that needs to be excluded in reads because further
new reads will be using only the newly created files out of compaction.
- compactedFiles - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- compactedFilesSupplier - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
-
- compactedFilesSupplier - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- compactedFilesSupplier - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
- compactedFilesSupplier - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- CompactedHFilesDischargeHandler - Class in org.apache.hadoop.hbase.regionserver
-
Event handler that handles the removal and archival of the compacted hfiles
- CompactedHFilesDischargeHandler(Server, EventType, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
-
- CompactedHFilesDischarger - Class in org.apache.hadoop.hbase.regionserver
-
A chore service that periodically cleans up the compacted files when there are no active readers
using those compacted files and also helps in clearing the block cache of these compacted file
entries.
- CompactedHFilesDischarger(int, Stoppable, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
- CompactedHFilesDischarger(int, Stoppable, RegionServerServices, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
- compactedInputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactedInputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- compactedOutputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactedOutputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- compactedStoreFiles - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- compactExecutor - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- compacting - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- COMPACTING_MEMSTORE_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- COMPACTING_MEMSTORE_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- COMPACTING_MEMSTORE_TYPE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- COMPACTING_MEMSTORE_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- compactingCellCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- compactingCellCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- CompactingMemStore - Class in org.apache.hadoop.hbase.regionserver
-
A memstore implementation which supports in-memory compaction.
- CompactingMemStore(Configuration, CellComparator, HStore, RegionServicesForStores, MemoryCompactionPolicy) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- compactingMemStore - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- CompactingMemStore.IndexType - Enum in org.apache.hadoop.hbase.regionserver
-
Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge
are applied.
- CompactingMemStore.InMemoryCompactionRunnable - Class in org.apache.hadoop.hbase.regionserver
-
The in-memory-flusher thread performs the flush asynchronously.
- compactingScanner - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
- compactingServers - Variable in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- compaction - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- COMPACTION - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- COMPACTION_AFTER_BULKLOAD_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Parameter name for compaction after bulkload
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes if the table is
compaction enabled.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- COMPACTION_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- COMPACTION_EVENT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for compaction event which contains the compacted storefiles in FileInfo
- COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the maximum batch of KVs to be used in flushes and compactions
- COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_POLICY_CLASS_FOR_DATE_TIERED_WINDOWS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- COMPACTION_PROGRESS_LOG_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- compactionChecker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Check for compactions requests.
- CompactionChecker(HRegionServer, int, Stoppable) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer.CompactionChecker
-
- compactionCheckFrequency - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactionCheckMultiplier - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- CompactionConfiguration - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Compaction configuration for a particular instance of HStore.
- CompactionConfiguration(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- CompactionContext - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all "physical" details necessary to run a compaction, and abstracts away the
details specific to a particular compaction.
- CompactionContext() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- compactionInputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactionInputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- CompactionInputFormat() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionInputFormat
-
- compactionInputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactionInputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- compactionKVMax - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- compactionKVMax - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- CompactionLifeCycleTracker - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
Used to track compaction execution.
- CompactionMapper() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- compactionNumBytesCompacted - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compactionNumFilesCompacted - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CompactionOrFlushMergeCopy(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- compactionOutputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactionOutputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- compactionOutputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactionOutputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- CompactionPipeline - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionPipeline(RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- CompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compaction policy determines how to select files for compaction, how to compact them, and how
to generate the compacted files.
- CompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- compactionPolicy - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- compactionPolicyForDateTieredWindow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- compactionPolicyPerWindow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- compactionPressure - Variable in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- compactionPressure - Variable in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- compactionProbability - Variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- CompactionProgress - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds information relevant for tracking the progress of a compaction.
- CompactionProgress(long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Constructor
- compactionQueues - Variable in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- compactionRatio - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- CompactionRequest - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
Coprocessors use this interface to get details about compaction.
- CompactionRequester - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
Request a compaction.
- CompactionRequestImpl - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all logical details necessary to run a compaction.
- CompactionRequestImpl(Collection<HStoreFile>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- CompactionRequestImpl.DisplayCompactionType - Enum in org.apache.hadoop.hbase.regionserver.compactions
-
- CompactionRunner(HStore, HRegion, CompactionContext, CompactionLifeCycleTracker, CompactSplit.CompactionCompleteTracker, ThreadPoolExecutor, User) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- COMPACTIONS_COMPLETED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_COMPLETED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_FAILED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_QUEUED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_QUEUED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- CompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for compaction.
- CompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- compactionsEnabled - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- compactionsFailed - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compactionsFinished - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compactionsQueued - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CompactionState - Enum in org.apache.hadoop.hbase.client
-
POJO representing the compaction state
- CompactionState() - Constructor for enum org.apache.hadoop.hbase.client.CompactionState
-
- compactionState - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- compactionState - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the compaction on or off.
- compactionSwitch(boolean, List<String>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compactionSwitch(boolean, List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compactionSwitch(boolean, List<String>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactionSwitch(RpcController, AdminProtos.CompactionSwitchRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- compactionSwitch(boolean, List<String>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compactionThreshold - Variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- compactionThroughputController - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- CompactionThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.throttle
-
- CompactionThroughputControllerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
-
- compactionTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- compactionTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- CompactionTool - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- CompactionTool.CompactionInputFormat - Class in org.apache.hadoop.hbase.regionserver
-
Input format that uses store files block location as input split locality.
- CompactionTool.CompactionMapper - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool.CompactionWorker - Class in org.apache.hadoop.hbase.regionserver
-
Class responsible to execute the Compaction on the specified path.
- CompactionWindow - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Base class for compaction window implementation.
- CompactionWindow() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
-
- CompactionWindowFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
-
For creating compaction window.
- CompactionWindowFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindowFactory
-
- CompactionWorker(FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
- compactLock - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- compactMin - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- compactMin - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- compactMin(int) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- compactMin() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- compactOnce - Variable in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- compactor - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- Compactor<T extends CellSink> - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compactor is a compaction algorithm associated a given policy.
- Compactor(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- compactor - Variable in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- compactor - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- Compactor.CellSinkFactory<S> - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
- Compactor.FileDetails - Class in org.apache.hadoop.hbase.regionserver.compactions
-
The sole reason this class exists is that java has no ref/out/pointer parameters.
- Compactor.InternalScannerFactory - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a region.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact a column family within a region.
- compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a region.
- compactRegion(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact an individual region.
- compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactRegion(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Compact a region on the master.
- compactRegion(Path, TableDescriptor, Path, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Compact a region on the region server.
- compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compactRegionOnServer(MajorCompactionRequest, Admin, String) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deprecated.
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- compactRegionsTTLOnTable(Configuration, String, int, long, int, int, boolean, boolean) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- compactRequest - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- CompactSplit - Class in org.apache.hadoop.hbase.regionserver
-
Compact region on request and then run split if appropriate
- CompactSplit(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- CompactSplit(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- CompactSplit.AggregatingCompleteTracker - Class in org.apache.hadoop.hbase.regionserver
-
- CompactSplit.CompactionCompleteTracker - Interface in org.apache.hadoop.hbase.regionserver
-
- CompactSplit.CompactionRunner - Class in org.apache.hadoop.hbase.regionserver
-
- CompactSplit.Rejection - Class in org.apache.hadoop.hbase.regionserver
-
Cleanup class to use when rejecting a compaction request from the queue.
- compactSplitThread - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactStore(byte[], ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact the given store.
- compactStoreFiles(Path, TableDescriptor, RegionInfo, String, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
Execute the actual compaction job.
- compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact all the stores synchronously.
- compactTable(Path, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
- compactTTLRegionsOnGroup(Configuration, String, int, long, int, int, boolean, boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
-
- CompactType - Enum in org.apache.hadoop.hbase.client
-
Currently, there are only two compact types: NORMAL
means do store files compaction;
MOB
means do mob files compaction.
- CompactType() - Constructor for enum org.apache.hadoop.hbase.client.CompactType
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.CellComparatorImpl
-
Comparator for plain key/values; i.e.
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.Row
-
- COMPARATOR - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- comparator - Variable in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
Comparator used to compare Bloom filter keys
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
Needed doing lookup on blocks.
- comparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- comparator - Variable in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.Segment
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- comparator - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- comparator - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- comparator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- comparator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- comparator - Variable in class org.apache.hadoop.hbase.util.BloomContext
-
- comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- comparator - Variable in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- comparator - Variable in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- comparator - Variable in class org.apache.hadoop.hbase.util.SortedList
-
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- COMPARATOR_IGNORE_REPLICATION - Static variable in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- comparatorClassName - Variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Raw key comparator class name in version 3
- ComparatorType() - Constructor for enum org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.ByteArrayComparableModel.ComparatorType
-
- compare(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares two cells.
- compare(Cell, Cell, boolean) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compare cells.
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compare(Cell, Cell, boolean) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compare(CellComparator, Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- compare(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This takes care if either of arguments are null.
- compare(CoprocessorEnvironment, CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.EnvironmentPriorityComparator
-
- compare(CompareFilter.CompareOp, int) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compare(CompareOperator, int) - Static method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compare(HDFSBlocksDistribution.HostAndWeight, HDFSBlocksDistribution.HostAndWeight) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Compare the timestamp to timerange.
- compare(CallRunner, CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.CallPriorityComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the Key of a cell -- with fields being more significant in this order: rowkey,
colfam/qual, timestamp, type, mvcc
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
Compare key portion of a
KeyValue
for keys in
hbase:meta
table.
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable.KeyValueWritableComparator
-
- compare(TransitRegionStateProcedure, TransitRegionStateProcedure) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- compare(RegionState, RegionState) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateStampComparator
-
- compare(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionInfoComparator
-
- compare(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor.SplitParentFirstComparator
-
- compare(RegionPlan, RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
-
- compare(Cell, Cell, boolean) - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compare(CellComparator, Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Used when a cell needs to be compared with a key byte[] such as cases of finding the index from
the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in
the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this
method cannot be used.
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- compare(KeyValueScanner, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
Compares two KeyValue nn * @return less than 0 if left is smaller, 0 if equal etc..
- compare(KeyValueScanner, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap.ReversedKVScannerComparator
-
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- compare(Option, Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool.OptionsOrderComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(Path, Path) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
-
- compareAndSetDataSize(long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- compareAndSetDataSize(long, long) - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- compareAndSetDataSize(long, long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- compareAndSetDataSize(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- compareAndSetMax(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- compareAndSetMin(long, long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- compareBBAndBytesRows(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareBBKV(ByteBufferKeyValue, ByteBufferKeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareBBRows(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareBytesRows(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareCacheBlock(Cacheable, Cacheable, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- compareCell(Cell, Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- compareCellKeysWithinRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
Compare families, qualifiers, and timestamps of the given Cells.
- compareColumns(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Compares the family and qualifier part of the cell
- compareColumns(Cell, int, int, Cell, int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareColumns(Cell, byte[], int, int, int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's column (family and qualifier) with the given byte[]
- compareColumns(Cell, short, Cell, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareColumns(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareCommonFamilyPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- compareCommonQualifierPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- compareCommonRowPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
common prefixes
- compareDelayed(Delayed, Delayed) - Static method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil
-
- compareFamilies(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the families of the two cells
- compareFamilies(Cell, int, Cell, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareFamilies(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Compare the families of left and right cell
- compareFamilies(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's family with the given byte[]
- compareFamilies(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareFamily(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareFamily(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareFamily(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compare cell's column family against given comparator
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
- CompareFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
- compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares left to right assuming that left,loffset,llength and right,roffset,rlength are full
KVs laid out in a flat byte[]s.
- compareFlatKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareHMAC(byte[], byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Overridden
- compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
-
Compare two keys assuming that the first n bytes are the same.
- compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- compareKey(CellComparator, Cell) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Compare the given key against the current key
- compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- compareKey(CellComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- compareKey(Cell, byte[], int, int, byte[], int, int, byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareKey(TKey) - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- compareKey(TNode, Object) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlKeyComparator
-
- compareKeyBasedOnColHint(CellComparator, Cell, Cell, int, int, byte[], int, int, long, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Used to compare two cells based on the column hint provided.
- compareKeyForNextColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- compareKeyForNextRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- compareKeyIgnoresMvcc(CellComparator, Cell, Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compares only the key portion of a cell.
- compareKeyValues(KeyValue, KeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareKVVsBBKV(KeyValue, ByteBufferKeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
- CompareOp() - Constructor for enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Deprecated.
- CompareOperator - Enum in org.apache.hadoop.hbase
-
Generic set of comparison operators.
- CompareOperator() - Constructor for enum org.apache.hadoop.hbase.CompareOperator
-
- compareOpFromHBase(CompareOperator) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- compareOpFromThrift(TCompareOp) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- comparePeerSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- compareQualifier(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifier(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareQualifier(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compare cell's qualifier against given comparator
- compareQualifierPart(Cell, int, byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- compareQualifiers(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the qualifiers of the two cells
- compareQualifiers(Cell, int, Cell, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareQualifiers(KeyValue, KeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareQualifiers(KeyValue, ByteBufferKeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareQualifiers(ByteBufferKeyValue, KeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareQualifiers(ByteBufferKeyValue, ByteBufferKeyValue) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareQualifiers(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Compare the qualifiers part of the left and right cells.
- compareQualifiers(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the cell's qualifier with the given byte[]
- Comparer() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.Comparer
-
Deprecated.
- compareRegionInfosWithoutReplicaId(RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- compareRegionsWithSplitKeys(List<HRegionLocation>, byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareResults(Result, Result, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- ComparerHolder() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder
-
Deprecated.
- compareRow(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRow(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareRow(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compare cell's row against given comparator
- compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the only the user specified portion of a Key.
- compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
Override the row key comparison to parse and compare the meta row key parts.
- compareRowKeys(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
Compare row keys of the given Result objects.
- compareRows(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexographically compares the rows of two cells.
- compareRows(Cell, byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
- compareRows(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares two row bytes
- compareRows(ByteBuffer, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compare two rows
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Compares the rows of the left and right cell.
- compareRows(Cell, int, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareRows(Cell, byte[], int, int) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the rows of a cell
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Get the b[],o,l for left and right rowkey portions and compare.
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareRows(Cell, byte[], int, int) - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareRows(byte[], byte[]) - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareRows(L, int, int, R, int, int, MetaCellComparator.SearchDelimiter<L>, MetaCellComparator.SearchDelimiter<R>, MetaCellComparator.SearchDelimiterInReverse<L>, MetaCellComparator.SearchDelimiterInReverse<R>, MetaCellComparator.Compare<L, R>) - Static method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareRows(ByteBuffer, Cell) - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap.ReversedKVScannerComparator
-
Compares rows of two KeyValue nn * @return less than 0 if left is smaller, 0 if equal etc..
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- compareServerName(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.master.RegionPlan
-
- compareTableWithPeerCluster(TableName, TableDescriptor, ReplicationPeerDescription, AsyncAdmin) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- compareTagsOrdinals(List<List<Integer>>, List<List<Integer>>) - Static method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- compareTimestamps(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTimestamps(long, long) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Compares cell's timestamps in DESCENDING order.
- compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareTimestamps(long, long) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareTimestamps(long, long) - Static method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
- compareTo(Action) - Method in class org.apache.hadoop.hbase.client.Action
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
- compareTo(ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- compareTo(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- compareTo(Row) - Method in interface org.apache.hadoop.hbase.client.Row
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(TableDescriptorBuilder.ModifyableTableDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(EventHandler) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Default prioritized runnable comparator which implements a FIFO ordering.
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.favored.StartcodeAgnosticServerName
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid copying byte[] unnecessarily.
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid copying bytes unnecessarily.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(MultiRowRangeFilter.BasicRowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- compareTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.RegexStringComparator.Engine
-
Match the given input against the configured pattern
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- compareTo(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(LruAdaptiveBlockCache.BlockBucket) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.BlockBucket
-
- compareTo(LruBlockCache.BlockBucket) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.BlockBucket
-
- compareTo(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- compareTo(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Define the sort order of the BytesWritable.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Compares the bytes in this object to the specified byte array n * @return Positive if left is
bigger than right, 0 if they are equal, and negative if left is smaller than right.
- compareTo(Delayed) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- compareTo(Import.CellWritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
-
- compareTo(Import.KeyValueWritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Compares this split against the given one.
- compareTo(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- compareTo(ServerStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- compareTo(ServerAndLoad) - Method in class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- compareTo(Queue<TKey>) - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- compareTo(RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Compare the region info.
- compareTo(RegionPlan, RegionPlan) - Static method in class org.apache.hadoop.hbase.master.RegionPlan
-
- compareTo(L, int, int, R, int, int) - Method in interface org.apache.hadoop.hbase.MetaCellComparator.Compare
-
- compareTo(CachedMobFile) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
- compareTo(Address) - Method in class org.apache.hadoop.hbase.net.Address
-
- compareTo(ByteBuff, int, int, ByteBuff, int, int) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Compares two ByteBuffs
- compareTo(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- compareTo(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- compareTo(Delayed) - Method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedObject
-
- compareTo(Delayed) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager.Lease
-
- compareTo(Delayed) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- compareTo(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- compareTo(MetricsTableSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- compareTo(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(Size) - Method in class org.apache.hadoop.hbase.Size
-
- compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
-
- compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Bitwise comparison of each byte in the array.
- compareTo(TNode) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
-
- compareTo(byte[], int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Comparer
-
Deprecated.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Comparer
-
Deprecated.
- compareTo(byte[], int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.PureJavaComparer
-
Deprecated.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.PureJavaComparer
-
Deprecated.
- compareTo(byte[], int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.UnsafeComparer
-
Deprecated.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.UnsafeComparer
-
Deprecated.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(byte[], int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(ByteBuffer, int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTo(T, int, int, T, int, int) - Method in interface org.apache.hadoop.hbase.util.Bytes.Comparer
-
- compareTo(Bytes) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Define the sort order of the Bytes.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Compares the bytes in this object to the specified byte array n * @return Positive if left is
bigger than right, 0 if they are equal, and negative if left is smaller than right.
- compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareTo(byte[], int, int, byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.PureJavaComparer
-
- compareTo(byte[], int, int, byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.UnsafeComparer
-
Lexicographically compare two arrays.
- compareTo(WALKey) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- compareTo(WALSplitUtil.MutationReplay) - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
-
- compareTo(Delayed) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.Task
-
- compareToIgnoreCase(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- compareToTimestamp(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
-
Compares the window to a timestamp.
- compareToTimestamp(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory.Window
-
- compareToUnsafe(Object, long, int, Object, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- compareTypeBytes(Cell, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
This method is used to determine a cell should be included or filtered out.
- compareValue(CompareFilter.CompareOp, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareValue(CompareOperator, ByteArrayComparable, Cell) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareValue(Cell, ByteArrayComparable) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compare cell's value against given comparator
- compareVersion(String, String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- compareWithoutRow(Cell, Cell) - Method in interface org.apache.hadoop.hbase.CellComparator
-
Lexicographically compares the two cells excluding the row part.
- compareWithoutRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- compareWithoutRow(int, byte[], int, int, byte[], int, int, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compare columnFamily, qualifier, timestamp, and key type (everything except the row).
- compareWithoutRow(CellComparator, Cell, byte[], int, int, short) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compare columnFamily, qualifier, timestamp, and key type (everything except the row).
- CompatibilityFactory - Class in org.apache.hadoop.hbase
-
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
- CompatibilityFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilityFactory
-
This is a static only class don't let any instance be created.
- CompatibilityLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- CompatibilitySingletonFactory - Class in org.apache.hadoop.hbase
-
Factory for classes supplied by hadoop compatibility modules.
- CompatibilitySingletonFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilitySingletonFactory
-
This is a static only class don't let anyone create an instance.
- CompatibilitySingletonFactory.SingletonStorage - Enum in org.apache.hadoop.hbase
-
- compatibleEarlyTermination - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if we should terminate access checks early as soon as table or CF grants allow access; pre-0.98
compatible behavior
- CompatStateSerializer(InputStream) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureUtil.CompatStateSerializer
-
- complete(TableName, AsyncNonMetaRegionLocator.LocateRequest, RegionLocations, Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- complete() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.RegionLocationsFutureResult
-
- complete - Variable in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- complete() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
For all time forward, do not throw an error because the process has completed.
- complete(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- complete(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- complete(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- complete(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- complete(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- complete(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- complete - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- complete() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Marks the compaction as complete by setting total to current KV count; Total KV count is an
estimate, so there might be a discrepancy otherwise.
- complete(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- complete(long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- completeAndWait(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- completeCacheFlush(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- completeCacheFlush(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- completeCacheFlush(byte[], long) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- completeCacheFlush(byte[], long) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Complete the cache flush.
- completeCheckTableState(CompletableFuture<Boolean>, TableState, Throwable, TableState.State, TableName) - Static method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Utility for completing passed TableState
CompletableFuture
future
using
passed parameters.
- completeConditionalOnFuture(CompletableFuture<T>, CompletableFuture<T>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- completed(Channel) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- completed - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- completed - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Map the the procId returned by submitProcedure(), the Root-ProcID, to the Procedure.
- completed() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker
-
Called after all the requested compactions are completed.
- completed(Store) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit.AggregatingCompleteTracker
-
- completed(Store) - Method in interface org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker
-
- completed - Variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
-
- completed - Variable in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- completed - Variable in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- completedLatch - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
latch for waiting until a procedure has completed
- completedLogsKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- CompletedProcedureCleaner<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Internal cleaner that removes the completed procedure results after a TTL.
- CompletedProcedureCleaner(Configuration, ProcedureStore, IdLock, Map<Long, CompletedProcedureRetainer<TEnvironment>>, Map<NonceKey, Long>) - Constructor for class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- CompletedProcedureRetainer<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Hold the reference to a completed root procedure.
- CompletedProcedureRetainer(Procedure<TEnvironment>) - Constructor for class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- completedRecoveryKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- completedRecoveryQueue - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- completedRecoveryQueue - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- completedSequenceId - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- completedSequenceId - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
n
- completedTasks - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- completedWAL - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- completedWAL - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- completeExceptionally() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- completeExceptionally(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeExceptionally(CompletableFuture<T>, Throwable) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- completeFile(DFSClient, ClientProtocol, String, String, ExtendedBlock, long) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- completeFlush(List<HStoreFile>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- completelyFreeBuckets - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- completelyFreeBuckets - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
- completelyFreeBuckets() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
How many buckets are currently claimed by this bucket size but as yet totally unused.
- completeManifest() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
This method completes mini-batch operations by calling postBatchMutate() CP hook (if
required) and completing mvcc.
- completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- completeNoMoreResults() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeOrNext(ClientProtos.ScanResponse, int) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeReversedWhenNoMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- CompleteScanResultCache - Class in org.apache.hadoop.hbase.client
-
A scan result cache that only returns complete result.
- CompleteScanResultCache() - Constructor for class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- completeSnapshot(Path, Path, FileSystem, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Commits the snapshot process by moving the working snapshot to the finalized filepath
- completeTracker - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- completeWhenError(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeWhenNoMoreResultsInRegion - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeWhenNoMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completeWithNextStartRow(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- completionCleanup(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- completionCleanup(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- completionCleanup(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- completionCleanup(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- completionCleanup(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called when the procedure is marked as completed (success or rollback).
- completionCleanup(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
The procedure in execution completed.
- completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- completionTime - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- completionTime - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- components - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- composeAttributeName(String, String) - Static method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
A helper function to compose the attribute name from tablename and costfunction name
- CompositeImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the
interface of a single ImmutableSegments.
- CompositeImmutableSegment(CellComparator, List<ImmutableSegment>) - Constructor for class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- compositeSnapshot - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- CompoundBloomFilter - Class in org.apache.hadoop.hbase.io.hfile
-
A Bloom filter implementation built on top of
BloomFilterChunk
, encapsulating a set of fixed-size Bloom
filters written out at the time of
HFile
generation into
the data block stream, and loaded on demand at query time.
- CompoundBloomFilter(DataInput, HFile.Reader, BloomFilterMetrics) - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
De-serialization for compound Bloom filter metadata.
- CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.io.hfile
-
- CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
- CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Adds methods required for writing a compound Bloom filter to the data section of an
HFile
to the
CompoundBloomFilter
class.
- CompoundBloomFilterWriter(int, float, int, int, boolean, CellComparator, BloomType) - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
n * each chunk's size in bytes.
- CompoundBloomFilterWriter.MetaWriter - Class in org.apache.hadoop.hbase.io.hfile
-
- CompoundBloomFilterWriter.ReadyChunk - Class in org.apache.hadoop.hbase.io.hfile
-
A Bloom filter chunk enqueued for writing
- CompoundConfiguration - Class in org.apache.hadoop.hbase
-
Do a shallow merge of multiple KV configuration pools.
- CompoundConfiguration() - Constructor for class org.apache.hadoop.hbase.CompoundConfiguration
-
Default Constructor.
- CompoundConfiguration.ImmutableConfigMap - Interface in org.apache.hadoop.hbase
-
- CompoundConfiguration.ImmutableConfWrapper - Class in org.apache.hadoop.hbase
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- compress(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- compress(byte[], Enum) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.BaosAndCompressor
-
- compress(byte[], Enum) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
-
- compress(byte[], Enum) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.NoneCompressor
-
- compress - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- compress() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Try to remove extraneous items from the set of sampled items.
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESS_TAGS_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- compressAfterEncoding(byte[], int, int, byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Compression algorithm used
- compressAndEncrypt(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- compressAndEncrypt(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Compress and encrypt the supplied encoded block data with header.
- compressedByteStream - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Underlying stream to write compressed bytes to
- compressedIn - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- CompressedKvDecoder(InputStream, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- CompressedKvEncoder(OutputStream, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvEncoder
-
- compressedOut - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- compressFamily(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- Compression - Class in org.apache.hadoop.hbase.io.compress
-
Compression related stuff.
- Compression() - Constructor for class org.apache.hadoop.hbase.io.compress.Compression
-
Prevent the instantiation of class.
- compression - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Compression algorithm used
- compression - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- compression() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- compression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Set the compression algorithm to use
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvEncoder
-
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
-
Compression algorithms.
- Compression.FinishOnFlushCompressionStream - Class in org.apache.hadoop.hbase.io.compress
-
- COMPRESSION_ALGORITHM_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- COMPRESSION_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION_COMPACT_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION_COMPACT_MAJOR_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_COMPACT_MINOR - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- COMPRESSION_COMPACT_MINOR_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- COMPRESSION_FAMILIES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- COMPRESSION_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- compressionAlgorithmFromHBase(Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- compressionAlgorithmFromThrift(TCompressionAlgorithm) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- compressionCodec - Variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
The compression codec used for all blocks.
- compressionCodec - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
Compression codec the client asked us use.
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- CompressionContext - Class in org.apache.hadoop.hbase.regionserver.wal
-
Context that holds the various dictionaries for compression in WAL.
- CompressionContext(Class<? extends Dictionary>, boolean, boolean, boolean, Compression.Algorithm) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- CompressionContext(Class<? extends Dictionary>, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Compression context to use reading.
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.BaosAndCompressor
-
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.StatelessUncompressor
-
- CompressionContext.DictionaryIndex - Enum in org.apache.hadoop.hbase.regionserver.wal
-
- CompressionContext.ValueCompressor - Class in org.apache.hadoop.hbase.regionserver.wal
-
Encapsulates the compression algorithm and its streams that we will use for value compression
in this WAL.
- compressionDetails - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Serialize column family to compression algorithm map to configuration.
- compressionOverhead(int) - Static method in class org.apache.hadoop.hbase.io.compress.CompressionUtil
-
Most compression algorithms can be presented with pathological input that causes an expansion
rather than a compression.
- CompressionState - Class in org.apache.hadoop.hbase.io.encoding
-
Stores the state of data block encoder at the beginning of new key.
- CompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- compressionStream - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Compression output stream
- CompressionTest - Class in org.apache.hadoop.hbase.util
-
Compression validation test.
- CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
-
- compressionTestResults - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
-
- CompressionUtil - Class in org.apache.hadoop.hbase.io.compress
-
- CompressionUtil() - Constructor for class org.apache.hadoop.hbase.io.compress.CompressionUtil
-
- compressName - Variable in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- compressor - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- compressor - Variable in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- compressor - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Compressor, which is also reused between consecutive blocks.
- compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- compressor - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- compressor - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- Compressor - Class in org.apache.hadoop.hbase.regionserver.wal
-
A set of static functions for running our custom WAL compression/decompression.
- Compressor() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
- compressQualifier(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- compressRow(OutputStream, Cell, Dictionary) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- compressSingleKeyValue(DataOutputStream, Cell, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- compressSingleKeyValue(DataOutputStream, Cell, Cell) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- compressTags - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Whether tags to be compressed or not
- compressTags - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Whether tags to be compressed or not
- compressTags(OutputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Compress tags one by one and writes to the OutputStream.
- compressTags(OutputStream, ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Compress tags one by one and writes to the OutputStream.
- compressTags(OutputStream, Cell, TagCompressionContext) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Compresses the tags to the given outputstream using the TagcompressionContext
- computeAndStoreSnapshotSizes(Collection<String>) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifier
-
Computes the size of a table and all of its snapshots, recording new "full" sizes for each.
- computeAndStoreSnapshotSizes(Collection<String>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
nn * @return the number of bits for a Bloom filter than can hold the given number of keys and
provide the given error rate, assuming that the optimal number of hash functions is used and it
does not have to be an integer.
- computeBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
- computeBulkLoadSize(FileSystem, List<String>) - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
-
- computeBulkLoadSize(FileSystem, List<String>) - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- computeBulkLoadSize(FileSystem, List<String>) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Computes the size of the file(s) at the given path against
this
policy and the
current
SpaceQuotaSnapshot
.
- computeCachedLocalities() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Computes and caches the locality for each region/rack combinations, as well as storing a
mapping of region -> server and region -> rack such that server and rack have the highest
locality for region
- computeCost(double[]) - Static method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- computeCost(BalancerClusterState, double) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
This is the main cost function.
- computeCostForRegionServer(int) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- computeCostForRegionServer(int) - Method in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- computeCryptoKeyHash(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the hash of the supplied argument, using the hash algorithm specified in the given
config.
- computeDelta(TableDescriptor, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorUtils
-
Compares two
TableDescriptor
and indicate which columns were added, deleted, or
modified from oldTD to newTD
- computedSteps - Variable in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- computedSteps - Variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- computedTotalCost - Variable in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- computedTotalCost - Variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This is a convenience method that computes a new filename with a given file-number.
- computeFoldableByteSize(long, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Increases the given byte size of a Bloom filter until it can be folded by the given factor.
- computeHDFSBlocksDistribution(Configuration, TableDescriptor, RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(Configuration, TableDescriptor, RegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Compute the HDFS Block Distribution for this StoreFile
- computeHDFSBlocksDistribution(HdfsDataInputStream) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compute HDFS block distribution of a given HdfsDataInputStream.
- computeHDFSBlocksDistribution(FileSystem, FileStatus, long, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compute HDFS blocks distribution of a given file, or a portion of the file
- computeHDFSBlocksDistributionInternal(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- computeIfAbsent(ConcurrentMap<K, V>, K, Supplier<V>) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
-
In HBASE-16648 we found that ConcurrentHashMap.get is much faster than computeIfAbsent if the
value already exists.
- computeIfAbsent(ConcurrentMap<K, V>, K, Supplier<V>, Runnable) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
-
- computeIfAbsentEx(ConcurrentMap<K, V>, K, ConcurrentMapUtils.IOExceptionSupplier<V>) - Static method in class org.apache.hadoop.hbase.util.ConcurrentMapUtils
-
In HBASE-16648 we found that ConcurrentHashMap.get is much faster than computeIfAbsent if the
value already exists.
- computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
The maximum number of keys we can put into a Bloom filter of a certain size to get the given
error rate, with the given number of hash functions.
- computeMergeNormalizationPlans(SimpleRegionNormalizer.NormalizeContext) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Computes the merge plans that should be executed for this table to converge average region
towards target average or target region count.
- computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- computeNumCallQueues(int, float) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- computePlansForTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
-
Computes a list of normalizer actions to perform on the target table.
- computePlansForTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- computeRefFileHDFSBlockDistribution(FileSystem, Reference, FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
helper function to compute HDFS blocks distribution of a given reference file.For reference
file, we don't compute the exact value.
- computeRegionInTransitionStat() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- computeSize(Region) - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Computes total FileSystem size for the given
Region
.
- computeSnapshotSizes(List<String>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Computes the size of each snapshot against the table referenced by this
.
- computeSnapshotSizes(Multimap<TableName, String>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Computes the size of each snapshot provided given the current files referenced by the table.
- computeSplitNormalizationPlans(SimpleRegionNormalizer.NormalizeContext) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Computes the split plans that should be executed for this table to converge average region size
towards target average or target region count.
- computeTrailerSizeByVersion() - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- ConcatenatedLists<T> - Class in org.apache.hadoop.hbase.util
-
A collection class that contains multiple sub-lists, which allows us to not copy lists.
- ConcatenatedLists() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- ConcatenatedLists.Iterator - Class in org.apache.hadoop.hbase.util
-
- concatenateExtraParams() - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
Returns extra parameter key/value string
- concatTags(byte[], Cell) - Static method in class org.apache.hadoop.hbase.TagUtil
-
- CONCURENT_FLUSH_TASKS_KEY - Static variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- CONCURENT_SNAPSHOT_TASKS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Maximum number of snapshot region tasks that can run concurrently
- CONCURRENCY_LEVEL - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
Anticipated number of concurrent accessor threads
- CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap
- CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Entry
- CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Segment
- CONCURRENT_PROCEDURES_COUNT - Static variable in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap
- CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap Entry
- concurrentCallsPerServer - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- concurrentCallsPerServerHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- concurrentCounterCache - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- ConcurrentMapUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for dealing with Collections, including treating null collections as empty.
- ConcurrentMapUtils() - Constructor for class org.apache.hadoop.hbase.util.ConcurrentMapUtils
-
- ConcurrentMapUtils.IOExceptionSupplier<V> - Interface in org.apache.hadoop.hbase.util
-
A supplier that throws IOException when get.
- concurrentServers - Variable in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- ConcurrentTableModificationException - Exception in org.apache.hadoop.hbase
-
Thrown when a table has been modified concurrently
- ConcurrentTableModificationException() - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
default constructor
- ConcurrentTableModificationException(String) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
Constructor
- ConcurrentTableModificationException(byte[]) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- ConcurrentTableModificationException(TableName) - Constructor for exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, String, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
- concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, ExecutorService, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
- conf - Variable in class org.apache.hadoop.hbase.BaseConfigurable
-
- conf - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- conf - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- conf - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- conf - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- conf - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- conf - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- conf - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
- conf - Variable in class org.apache.hadoop.hbase.client.RetryingCallerInterceptorFactory
-
- conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- conf - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- conf - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- conf - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- conf - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- conf - Variable in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- conf - Variable in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
-
- conf - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- conf - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- conf - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- conf - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- conf - Variable in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- conf - Variable in class org.apache.hadoop.hbase.io.crypto.Context
-
- conf - Variable in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- conf - Variable in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- conf - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- conf - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- conf - Variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The current configuration.
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
The configuration.
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The configuration.
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
The configuration.
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- conf - Variable in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
- conf - Variable in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- conf - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- conf - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- conf - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- conf - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- conf - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- conf - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- conf - Variable in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- conf - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- conf - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.master.SplitWALManager
-
- conf - Variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- conf - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- conf - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- conf - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- conf - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl.CacheKey
-
- conf - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- conf - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- conf - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- conf - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
- conf - Variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- conf - Static variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook.ShutdownHookThread
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.StoreFlusher
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
conf object
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- conf - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- conf - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
- conf - Variable in class org.apache.hadoop.hbase.rest.client.Client
-
- conf - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- conf - Variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- conf - Variable in class org.apache.hadoop.hbase.security.access.AuthManager
-
- conf - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- conf - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- conf - Variable in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
- conf - Variable in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- conf - Variable in class org.apache.hadoop.hbase.security.provider.BuiltInProviderSelector
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- conf - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityReplication
-
- conf - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- conf - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- conf - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- conf - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- conf - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- conf - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- conf(Configuration) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- conf - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
Configuration for this testing cluster.
- conf() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- conf - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- conf - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- conf - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- conf - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- conf - Variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- conf - Variable in class org.apache.hadoop.hbase.util.ConnectionCache
-
- conf - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.FileLockCallable
-
Deprecated.
- conf - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- conf - Variable in class org.apache.hadoop.hbase.util.HbckTableInfo.HDFSIntegrityFixer
-
- conf - Variable in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- conf - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- conf - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- conf - Variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- conf - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- CONF_BANDWIDTH_MB - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_CHECKSUM_VERIFY - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_COMPACT_MAJOR - Static variable in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- CONF_COMPACT_ONCE - Static variable in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- CONF_CONTEXT_ATTRIBUTE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- CONF_COPY_MANIFEST_THREADS - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_DELETE_COMPACTED - Static variable in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- CONF_DEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the destination filesystem
- CONF_FILES_GROUP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_FILES_MODE - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_FILES_USER - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_INPUT_ROOT - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_MAP_GROUP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_MR_JOB_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_NUM_SPLITS - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_OUTPUT_ROOT - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SNAPSHOT_DIR - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SNAPSHOT_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONF_SOURCE_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Configuration prefix for overrides for the source filesystem
- CONF_TEST_FAILURE - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Testing
-
- CONF_TEST_FAILURE_COUNT - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Testing
-
- confDefault - Variable in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes class names that appear in user facing configuration files.
- config - Variable in class org.apache.hadoop.hbase.HealthCheckChore
-
- config - Variable in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- config - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- config - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- config - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- config - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- config - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
- CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper
-
- configs - Variable in class org.apache.hadoop.hbase.CompoundConfiguration
-
- configuration - Variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
A map which holds the configuration specific to the column family.
- configuration - Variable in class org.apache.hadoop.hbase.client.HTable
-
- CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- configuration - Variable in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
- configuration - Variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- configuration - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- configuration - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- configuration - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- configuration - Variable in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- configuration - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- ConfigurationManager - Class in org.apache.hadoop.hbase.conf
-
Maintains the set of all the classes which would like to get notified when the Configuration is
reloaded from the disk in the Online Configuration Change mechanism, which lets you update
certain configuration properties on-the-fly, without having to restart the cluster.
- ConfigurationManager() - Constructor for class org.apache.hadoop.hbase.conf.ConfigurationManager
-
- configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Configuration manager is used to register/deregister and notify the configuration observers
when the regionserver is notified that there was a change in the on disk configs.
- ConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
-
Every class that wants to observe changes in Configuration properties, must implement interface
(and also, register itself with the
ConfigurationManager
.
- configurationObservers - Variable in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
- ConfigurationUtil - Class in org.apache.hadoop.hbase.util
-
Utilities for storing more complex collection types in
Configuration
instances.
- ConfigurationUtil() - Constructor for class org.apache.hadoop.hbase.util.ConfigurationUtil
-
- configure(Configuration, boolean, long) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Setup the configuration for a constraint as to whether it is enabled and its priority n * on
which to base the new configuration n * true if it should be run n * relative to other
constraints
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- configure() - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
Adds a configuration to the Context disabling remote rpc'ing to figure Region size when
calculating InputSplits.
- configure() - Method in class org.apache.hadoop.hbase.master.http.gson.GsonSerializationFeature.Binder
-
- configure(FeatureContext) - Method in class org.apache.hadoop.hbase.master.http.gson.GsonSerializationFeature
-
- configure() - Method in class org.apache.hadoop.hbase.master.http.jersey.MasterFeature.Binder
-
- configure(FeatureContext) - Method in class org.apache.hadoop.hbase.master.http.jersey.MasterFeature
-
- configure(Configuration, Collection<SaslClientAuthenticationProvider>) - Method in interface org.apache.hadoop.hbase.security.provider.AuthenticationProviderSelector
-
Initializes the implementation with configuration and a set of providers available.
- configure(Configuration, Collection<SaslClientAuthenticationProvider>) - Method in class org.apache.hadoop.hbase.security.provider.BuiltInProviderSelector
-
- configure(Configuration, Collection<SaslClientAuthenticationProvider>) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeProviderSelector
-
- configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets a configuration property with key
Import.CF_RENAME_PROP
in conf that tells the mapper
how to rename column families.
- configuredReadTableTimeouts - Variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
This is a Map of table to timeout.
- configuredReadTableTimeouts - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
This is a timeout per table.
- configuredWriteTableTimeout - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
Deprecated.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
Upon construction, this method will be called with the region to be governed.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Upon construction, this method will be called with the region to be governed.
- configureHBaseRpcController(RpcController, int) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Configure an hbase rpccontroller
- configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given table.
- configureIncrementalLoad(Job, TableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given table.
- configureIncrementalLoad(Job, List<HFileOutputFormat2.TableInfo>, Class<? extends OutputFormat<?, ?>>) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureIncrementalLoad(Job, List<HFileOutputFormat2.TableInfo>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- configureIncrementalLoadMap(Job, TableDescriptor) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
Job configuration.
- configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
Job configuration.
- configurePartitioner(Job, List<ImmutableBytesWritable>, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure job
with a TotalOrderPartitioner, partitioning against
splitPoints
.
- configureRemoteCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure HBase cluster key for remote cluster to load region location for locality-sensitive
if it's enabled.
- configureRpcController(RpcController) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
-
Configure an rpc controller
- configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets split table in map-reduce job.
- configureStoragePolicy(Configuration, FileSystem, byte[], Path) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure block storage policy for CF after the directory is created.
- confirmClosed(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- confirmOpened(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- confKey - Variable in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- conflictWaitIterationMs - Variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
The time to wait in an extremely unlikely case of a conflict with a running op.
- ConfServlet - Class in org.apache.hadoop.hbase.http.conf
-
A servlet to print out the running configuration data.
- ConfServlet() - Constructor for class org.apache.hadoop.hbase.http.conf.ConfServlet
-
- ConfServlet.BadFormatException - Exception in org.apache.hadoop.hbase.http.conf
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- conn - Variable in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- conn - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- conn - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- conn - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- conn - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- conn - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
- conn - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- conn - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- conn - Variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- conn - Variable in class org.apache.hadoop.hbase.master.cleaner.ReplicationBarrierCleaner
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl.CacheKey
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- conn - Variable in class org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
-
- conn - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- conn - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- conn - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- conn - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- conn - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- conn - Variable in class org.apache.hadoop.hbase.SharedConnection
-
- conn - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
-
- conn - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- connConf - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- connConfiguration - Variable in class org.apache.hadoop.hbase.client.HTable
-
- connect(Configuration) - Method in interface org.apache.hadoop.hbase.client.ClusterStatusListener.Listener
-
Called to connect.
- connect(Configuration) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener
-
- connect(CompletableFuture<T>, CompletableFuture<T>, Optional<MetricsConnection>) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Connect the two futures, if the src future is done, then mark the dst future as done.
- connect(URL) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
Connect to the URL.
- connect() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- connect(Configuration) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- connect(Configuration) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
To repair region consistency, one must call connect() in order to repair online state.
- connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Creates a new connection to ZooKeeper, pulling settings and ensemble config from the specified
configuration object using methods from
ZKConfig
.
- connected - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- connected - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- connectFailed(Exception) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.Task
-
- connectFailed(Exception) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.ZKTask
-
- connection - Variable in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
- connection - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- connection - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- Connection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
- connection - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- connection - Variable in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- connection - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- connection - Variable in class org.apache.hadoop.hbase.client.HRegionLocator
-
- connection - Variable in class org.apache.hadoop.hbase.client.HTable
-
- connection - Variable in class org.apache.hadoop.hbase.client.MasterCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- connection - Variable in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- connection - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- connection - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- connection - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- connection - Variable in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- connection - Variable in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- connection - Variable in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
- connection - Variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- connection - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- connection - Variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
- connection - Variable in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- connection - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- connection - Variable in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure.UnknownServerVisitor
-
- connection - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- connection - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- connection - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- connection - Variable in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
Connection to use.
- connection - Variable in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- connection - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- connection - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- connection - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- connection - Static variable in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
- connection - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftClientBuilder
-
- connection - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- connection - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- connection - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- connection - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperTask
-
- connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- connection - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- connection - Variable in class org.apache.hadoop.hbase.util.ConnectionCache.ConnectionInfo
-
- connection - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- connection - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemRegion
-
Deprecated.
- CONNECTION_EXCEPTION_TYPES - Static variable in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- connectionCache - Variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- connectionCache - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- ConnectionCache - Class in org.apache.hadoop.hbase.util
-
A utility to store user specific HConnections in memory.
- ConnectionCache(Configuration, UserProvider, int, int) - Constructor for class org.apache.hadoop.hbase.util.ConnectionCache
-
- ConnectionCache.ConnectionInfo - Class in org.apache.hadoop.hbase.util
-
- ConnectionClosedException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the connection is closed
- ConnectionClosedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
ConnectionClosedException with cause
- ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the client believes that we are trying to communicate to has been repeatedly
unresponsive for a while.
- ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
- ConnectionClosingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
ConnectionClosingException with cause
- connectionConf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- connectionConfig - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- connectionConfiguration - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- ConnectionConfiguration - Class in org.apache.hadoop.hbase.client
-
Configuration parameters for the connection.
- ConnectionConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
Constructor
- ConnectionConfiguration() - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
Constructor This is for internal testing purpose (using the default value).
- connectionEvent(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Called when there is a connection-related event via the Watcher callback.
- ConnectionFactory - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
Connection
s.
- ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- connectionHeader - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- connectionHeaderPreamble - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- connectionHeaderPreamble - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- connectionHeaderRead - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- connectionHeaderWithLength - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- connectionHeaderWithLength - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- connectionHeaderWithLength - Variable in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
- ConnectionId - Class in org.apache.hadoop.hbase.ipc
-
This class holds the address and the user ticket, etc.
- ConnectionId(User, String, Address) - Constructor for class org.apache.hadoop.hbase.ipc.ConnectionId
-
- ConnectionImplementation - Class in org.apache.hadoop.hbase.client
-
- ConnectionImplementation(Configuration, ExecutorService, User) - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation
-
constructor
- ConnectionImplementation(Configuration, ExecutorService, User, ConnectionRegistry) - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Constructor, for creating cluster connection with provided ConnectionRegistry.
- ConnectionImplementation.LocalConnectionClosedException - Exception in org.apache.hadoop.hbase.client
-
- ConnectionImplementation.MasterServiceState - Class in org.apache.hadoop.hbase.client
-
State of the MasterService connection/setup.
- ConnectionImplementation.MasterServiceStubMaker - Class in org.apache.hadoop.hbase.client
-
Class to make a MasterServiceStubMaker stub.
- ConnectionImplementation.ServerErrorTracker - Class in org.apache.hadoop.hbase.client
-
The record of errors for servers.
- ConnectionImplementation.ServerErrorTracker.ServerErrors - Class in org.apache.hadoop.hbase.client
-
The record of errors for a server.
- ConnectionInfo(Connection, String) - Constructor for class org.apache.hadoop.hbase.util.ConnectionCache.ConnectionInfo
-
- connectionLossFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- connectionManager - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- ConnectionManager() - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- connectionPreambleRead - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- ConnectionRegistry - Interface in org.apache.hadoop.hbase.client
-
Registry for meta information needed for connection setup to a HBase cluster.
- ConnectionRegistryFactory - Class in org.apache.hadoop.hbase.client
-
Factory class to get the instance of configured connection registry.
- ConnectionRegistryFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionRegistryFactory
-
- connections - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- connections - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- connections - Variable in class org.apache.hadoop.hbase.util.ConnectionCache
-
- connections - Variable in class org.apache.hadoop.hbase.util.MultiHConnection
-
- connectionsLock - Variable in class org.apache.hadoop.hbase.util.MultiHConnection
-
- ConnectionSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
-
Construct Span
instances originating from the client side of a connection.
- ConnectionSpanBuilder(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- connectionString - Variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- connectionString - Variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- connectionTimeout - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- ConnectionUtils - Class in org.apache.hadoop.hbase.client
-
Utility used by client connections.
- ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
-
- ConnectionUtils.MasterlessConnection - Class in org.apache.hadoop.hbase.client
-
Some tests shut down the master.
- connectString - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- connectTimeout - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- connectTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- connectToDataNodes(Configuration, DFSClient, String, LocatedBlock, long, long, BlockConstructionStage, DataChecksum, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- connectToPeers() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- consecutiveLogRolls - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- Consistency - Enum in org.apache.hadoop.hbase.client
-
Consistency defines the expected consistency level for an operation.
- Consistency() - Constructor for enum org.apache.hadoop.hbase.client.Consistency
-
- consistency - Variable in class org.apache.hadoop.hbase.client.Query
-
- consistencyFromHBase(Consistency) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- consistencyFromThrift(TConsistency) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- consolidate() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- Constants - Interface in org.apache.hadoop.hbase.rest
-
Common constants for org.apache.hadoop.hbase.rest
- Constants - Class in org.apache.hadoop.hbase.thrift
-
Thrift related constants
- Constants() - Constructor for class org.apache.hadoop.hbase.thrift.Constants
-
- ConstantSizeRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
RegionSplitPolicy
implementation which splits a region as soon as any of its store
files exceeds a maximum configurable size.
- ConstantSizeRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- constrainHttpMethods(ServletContextHandler, boolean) - Static method in class org.apache.hadoop.hbase.http.HttpServerUtil
-
Add constraints to a Jetty Context to disallow undesirable Http methods.
- Constraint - Interface in org.apache.hadoop.hbase.constraint
-
Apply a
Constraint
(in traditional database terminology) to a HTable.
- CONSTRAINT_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- CONSTRAINT_HTD_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- constraintComparator - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- ConstraintException - Exception in org.apache.hadoop.hbase.constraint
-
Exception that a user defined constraint throws on failure of a
Put
.
- ConstraintException() - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintProcessor - Class in org.apache.hadoop.hbase.constraint
-
- ConstraintProcessor() - Constructor for class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
Create the constraint processor.
- constraints - Variable in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- Constraints - Class in org.apache.hadoop.hbase.constraint
-
Utilities for adding/removing constraints from a table.
- Constraints() - Constructor for class org.apache.hadoop.hbase.constraint.Constraints
-
- constructMaster(Class<? extends HMaster>, Configuration) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
Utility for constructing an instance of the passed HMaster class.
- constructor - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler.BuilderPayloadSetter
-
- constructRegionServer(Class<? extends HRegionServer>, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Utility for constructing an instance of the passed HRegionServer class.
- constructRowProcessorFromRequest(RowProcessorProtos.ProcessRequest) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- consume() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
consume one available unit.
- consume(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
consume amount available units, amount could be a negative number
- consume() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- consume(CompletableFuture<?>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
Log the error if the future indicates any failure.
- consume(Future<?>) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Log the error if the future indicates any failure.
- CONSUMED_CLUSTER_IDS - Static variable in class org.apache.hadoop.hbase.client.Mutation
-
The attribute for storing the list of clusters that have consumed the change.
- consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- consumeEventFromDisruptor(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
This implementation is specific to slowLog event.
- consumeEventFromDisruptor(NamedQueuePayload) - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
This implementation is generic for consuming records from LMAX disruptor and inserts records to
EvictingQueue which is maintained by each ringbuffer provider.
- consumeExecutor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- consumeLock - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- consumer - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- consumer - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- consumer(AdvancedScanResultConsumer) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- consumer - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- consumer - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- consumeRead(long, long) - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- consumeRead(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some read amount to the quota.
- consumeRead(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- consumerLoop(BlockingQueue<HFileCleaner.HFileDeleteTask>) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- consumerScheduled - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- consumeWrite(long, long) - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- consumeWrite(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some write amount to the quota.
- consumeWrite(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- container - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteArrayBackedNode
-
- container - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteBufferBackedNode
-
- Container(Counter.Cell) - Constructor for class org.apache.hadoop.hbase.util.Counter.Container
-
Deprecated.
- Container(Counter.Cell[]) - Constructor for class org.apache.hadoop.hbase.util.Counter.Container
-
Deprecated.
- CONTAINER_DB_OPERATIONS_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- containerRef - Variable in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- containMetaWals(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- containReadAction(UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- contains(byte[]) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- contains(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- contains(String) - Static method in class org.apache.hadoop.hbase.io.compress.DictionaryCache
-
- contains(byte[], int, int, ByteBuff) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- contains(Cell, ByteBuff, BloomType) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- contains(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- contains(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- contains(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- contains(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- contains(ReplicationPeerConfig, TableName) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- contains(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- contains(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- contains(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- contains(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- contains(Cell, ByteBuff, BloomType) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
Check if the specified key is contained in the bloom filter.
- contains(byte[], int, int, ByteBuff) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
Check if the specified key is contained in the bloom filter.
- contains(byte[], int, int, ByteBuff, int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
- contains(ByteBuff, int, int, Hash, int, HashKey<T>) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
- contains(Cell, ByteBuff, int, int, Hash, int, BloomType) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if target is present as an element anywhere in the given array.
- contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if target is present as an element anywhere in the given array.
- contains(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- containsBlock(BlockCacheKey) - Method in interface org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
-
Whether the cache contains the block with specified cacheKey
- containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Whether the cache contains block with specified cacheKey
- containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Whether the cache contains block with specified cacheKey
- containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- containsBogusAssignments(Map<RegionInfo, RegionStateNode>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsIgnoreMvccVersion(Collection<? extends Cell>, Collection<? extends Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
- containsInternal(byte[], int, int, ByteBuff) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- containsInternal(Cell, ByteBuff, BloomType) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- containsKey(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- containsMetaTableRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsOnlyHdfsEdits() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns true if the given inclusive range of rows is fully contained by this region.
- containsRange(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if the given inclusive range of rows is fully contained by this region.
- containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if the given inclusive range of rows is fully contained by this region.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Return true if the given row falls in this region.
- containsRow(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if the given row falls in this region.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if the given row falls in this region.
- containsServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Returns true if a server with hostPort is found
- containsTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
- containsTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- containsUpperCase(Iterable<String>) - Static method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- CONTENT_TYPE_TEXT - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- contentType - Variable in class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
-
- context - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- Context(Configuration) - Constructor for class org.apache.hadoop.hbase.io.crypto.Context
-
- Context() - Constructor for class org.apache.hadoop.hbase.io.crypto.Context
-
- Context() - Constructor for class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- Context(Configuration) - Constructor for class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- context - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
-
- context - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- Context() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
-
- context - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- context - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- context - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- context - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- Context(Configuration, Configuration, FileSystem, String, UUID, ReplicationPeer, MetricsSource, TableDescriptors, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- context - Variable in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
-
- CONTEXT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
Used to place extract attributes pertaining to the
HFileContext
that scopes the active
Context
.
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- control(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Control the throughput.
- controller - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner.OpenScannerResponse
-
- controller - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- controller - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- controller - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- controller - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- controller - Variable in class org.apache.hadoop.hbase.wal.EntryBuffers
-
- controller - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
- controller - Variable in class org.apache.hadoop.hbase.wal.OutputSink.WriterThread
-
- controllerConnectionFailure(String, Throwable, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
The connection to the rest of the procedure group (member and coordinator) has been
broken/lost/failed.
- controlPerSize - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- convert(S) - Method in interface org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.Converter
-
- convert(I, S) - Method in interface org.apache.hadoop.hbase.client.RawAsyncTableImpl.Converter
-
- convert(I, S, long, long) - Method in interface org.apache.hadoop.hbase.client.RawAsyncTableImpl.NoncedConverter
-
- convert(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
convert map to TableCFs Object
- convert(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert string to TableCFs Object.
- convert(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert TableCFs Object to String.
- convert(ReplicationProtos.ReplicationPeer) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convert(ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convert() - Method in class org.apache.hadoop.hbase.client.TableState
-
Covert to PB version of TableState n
- convert(TableName, HBaseProtos.TableState) - Static method in class org.apache.hadoop.hbase.client.TableState
-
Covert from PB version of TableState
- convert(HBaseProtos.TableState.State) - Static method in enum org.apache.hadoop.hbase.client.TableState.State
-
Covert from PB version of State
- convert() - Method in enum org.apache.hadoop.hbase.client.TableState.State
-
Covert to PB version of State n
- convert(byte[]) - Method in interface org.apache.hadoop.hbase.client.ZKConnectionRegistry.Converter
-
- convert() - Method in class org.apache.hadoop.hbase.ClusterId
-
Returns A pb instance to represent this instance.
- convert(ClusterIdProtos.ClusterId) - Static method in class org.apache.hadoop.hbase.ClusterId
-
n * @return A
ClusterId
made from the passed in
cid
- convert() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns A pb instance to represent this instance.
- convert() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Returns A pb instance to represent this instance.
- convert() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- convert() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Convert a HRegionInfo to the protobuf RegionInfo
- convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- convert() - Method in class org.apache.hadoop.hbase.io.Reference
-
- convert(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- convert(MasterProcedureProtos.RegionTransitionType) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- convert(TransitRegionStateProcedure.TransitionType) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- convert(MasterProtos.MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- convert() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a RegionState to an HBaseProtos.RegionState
- convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a protobuf HBaseProtos.RegionState to a RegionState
- convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert to protobuf ClusterStatusProtos.RegionState.State
- convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
- convert() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
- convert() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Convert to
org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
protobuf.
- convert() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
Convert to the internal option.
- convert(Map<LoadIncrementalHFiles.LoadQueueItem, ByteBuffer>) - Method in class org.apache.hadoop.hbase.tool.BulkLoadHFilesTool
-
- convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- convert2Map(ReplicationProtos.TableCF[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert tableCFs Object to Map.
- CONVERT_TO_PERCENTAGE - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- CONVERT_TO_PERCENTAGE - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a boolean expressed in a byte array to an actual boolean
- convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts an int expressed in a byte array to an actual int
- convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a long expressed in a byte array to an actual long
- Converter() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- Converter() - Constructor for class org.apache.hadoop.hbase.util.Bytes.Converter
-
- ConverterHolder() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder
-
Deprecated.
- ConverterHolder() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ConverterHolder
-
- convertInterruptedExceptionToIOException(InterruptedException) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- convertKv(Cell, Map<byte[], byte[]>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
- convertRegionSize(RegionInfo, Long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Converts a pair of
RegionInfo
and
long
into a
RegionServerStatusProtos.RegionSpaceUse
protobuf
message.
- convertResult(MasterProtos.GetProcedureResultResponse) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
Convert the procedure result response to a specified type.
- convertScanToString(Scan) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Writes the given scan into a Base64 encoded string.
- convertSnapshot(SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- convertStringToScan(String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Converts the given Base64 string back into a Scan instance.
- convertThrowableToIOE(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Returns the BigInteger represented by the byte array
- convertToByte(BigInteger, int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Returns an array of bytes corresponding to an array of BigIntegers
- convertToFutureOfList(List<CompletableFuture<T>>) - Static method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- convertToProcedure(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
Helper to convert the protobuf procedure.
- convertToProcedureMetrics(OperationMetrics) - Static method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- convertToProtoLockedResource(LockedResource) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- convertToProtoLockType(LockType) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- convertToProtoProcedure(Procedure<?>) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
Helper to convert the procedure to protobuf.
- convertToProtoResourceType(LockedResourceType) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- convertToString(Set<String>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convertToString(Map<TableName, ? extends Collection<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- convertToUnit(String) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- convertToV2SingleManifest() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- COOKIE - Static variable in class org.apache.hadoop.hbase.rest.client.Client
-
- coord - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- CoordinatedStateManager - Interface in org.apache.hadoop.hbase
-
Implementations of this interface will keep and return to clients implementations of classes
providing API to execute coordinated operations.
- coordination - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- coordination - Variable in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- coordinator - Variable in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
- coordinator - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- coordinator - Variable in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
- coordName - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
- Copier(FileSystem, Path, List<String>) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator.Copier
-
- copiesPerThread - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- coprocEnvironments - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Ordered set of loaded coprocessors with lock
- Coprocessor - Interface in org.apache.hadoop.hbase
-
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
- Coprocessor.State - Enum in org.apache.hadoop.hbase
-
Lifecycle state of a given coprocessor instance.
- COPROCESSOR_EXECUTION_STATISTICS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COPROCESSOR_EXECUTION_STATISTICS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- CoprocessorClassLoader - Class in org.apache.hadoop.hbase.util
-
ClassLoader used to load classes for Coprocessor instances.
- CoprocessorClassLoader(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Creates a JarClassLoader that loads classes from the given paths.
- CoprocessorConfigurationUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for coprocessor host when configuration changes.
- CoprocessorConfigurationUtil() - Constructor for class org.apache.hadoop.hbase.util.CoprocessorConfigurationUtil
-
- CoprocessorDescriptor - Interface in org.apache.hadoop.hbase.client
-
CoprocessorDescriptor contains the details about how to build a coprocessor.
- CoprocessorDescriptorBuilder - Class in org.apache.hadoop.hbase.client
-
- CoprocessorDescriptorBuilder(String) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl - Class in org.apache.hadoop.hbase.client
-
- CoprocessorDescriptorImpl(String, String, int, Map<String, String>) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- CoprocessorEnvironment<C extends Coprocessor> - Interface in org.apache.hadoop.hbase
-
Coprocessor environment state.
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- CoprocessorHost<C extends Coprocessor,E extends CoprocessorEnvironment<C>> - Class in org.apache.hadoop.hbase.coprocessor
-
Provides the common setup framework and runtime services for coprocessor invocation from HBase
services.
- CoprocessorHost(Abortable) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- coprocessorHost - Variable in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- CoprocessorHost.EnvironmentPriorityComparator - Class in org.apache.hadoop.hbase.coprocessor
-
Environment priority comparator.
- CoprocessorHost.ObserverGetter<C,O> - Interface in org.apache.hadoop.hbase.coprocessor
-
Implementations defined function to get an observer of type O
from a coprocessor of
type C
.
- CoprocessorHost.ObserverOperation<O> - Class in org.apache.hadoop.hbase.coprocessor
-
- CoprocessorHost.ObserverOperationWithoutResult<O> - Class in org.apache.hadoop.hbase.coprocessor
-
- CoprocessorHost.ObserverOperationWithResult<O,R> - Class in org.apache.hadoop.hbase.coprocessor
-
- CoprocessorMethod - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorMethod(String) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
-
- CoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
-
- coprocessorNames - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Not to be confused with the per-object _coprocessors_ (above), coprocessorNames is static and
stores the set of all coprocessors ever loaded by any thread in this JVM.
- coprocessorNames - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- coprocessorNames - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- CoprocessorRpcChannel - Interface in org.apache.hadoop.hbase.ipc
-
Base interface which provides clients with an RPC connection to call coprocessor endpoint
Service
s.
- CoprocessorRpcUtils - Class in org.apache.hadoop.hbase.ipc
-
Utilities for handling coprocessor rpc service calls.
- CoprocessorRpcUtils() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- CoprocessorRpcUtils.BlockingRpcCallback<R> - Class in org.apache.hadoop.hbase.ipc
-
- COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance connected to the active
master.
- coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance connected to the passed
region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the master.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Execute the given coprocessor call on the given region server.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute the given coprocessor call on the region which contains the given row
.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Execute a coprocessor call on the regions which are covered by a range.
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates and returns a RpcChannel
instance connected to the table
region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- coprocessorService() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- CoprocessorServiceBackwardCompatiblity - Class in org.apache.hadoop.hbase.coprocessor
-
Deprecated.
- CoprocessorServiceBackwardCompatiblity() - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity
-
Deprecated.
- CoprocessorServiceBackwardCompatiblity.MasterCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
-
Deprecated.
- CoprocessorServiceBackwardCompatiblity.RegionCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
-
Deprecated.
- CoprocessorServiceBackwardCompatiblity.RegionServerCoprocessorService - Class in org.apache.hadoop.hbase.coprocessor
-
Deprecated.
- CoprocessorServiceBuilderImpl(Function<RpcChannel, S>, ServiceCaller<S, R>, AsyncTable.CoprocessorCallback<R>) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- coprocessorServiceHandlers - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- coprocessorServiceHandlers - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- coprocessorServiceHandlers - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CoprocessorValidator - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorValidator() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- CoprocessorValidator.ResolverUrlClassLoader - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorViolation - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorViolation(String, CoprocessorViolation.Severity, String) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- CoprocessorViolation(String, CoprocessorViolation.Severity, String, Throwable) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- CoprocessorViolation.Severity - Enum in org.apache.hadoop.hbase.tool.coprocessor
-
- CoprocessorWhitelistMasterObserver - Class in org.apache.hadoop.hbase.security.access
-
Master observer for restricting coprocessor assignments.
- CoprocessorWhitelistMasterObserver() - Constructor for class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
- copy(ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- copy(TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(TableName, TableDescriptor) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- copy(ScannerContext.LimitFields) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance of a new byte array with the same
length and the same content.
- copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance of a new byte array with the same
length and the same content.
- copy(byte[], int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Copies the bytes from given array's offset to length part into the given buffer.
- copy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Copies specified number of bytes from given offset of src
ByteBuffer to the
dest
array.
- copy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Copies specified number of bytes from given offset of src
buffer into the dest
buffer.
- COPY_FROM - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- COPY_TO - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- copyActiveEnforcements() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns the collection of tables which have quota violation policies enforced on this
RegionServer.
- copyBBECellInto(ByteBufferExtendedCell, int) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- copyBBECToChunkCell(ByteBufferExtendedCell, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
out of it
- copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy data from a buffer to an output stream.
- copyBufferToStream(DataOutput, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy data from a buffer to an output stream.
- copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns a copy of the bytes referred to by this writable
- copyBytes() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a copy of the bytes referred to by this writable
- copyCellInto(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- copyCellInto(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocates slice in this LAB and copy the passed Cell into this area.
- copyCellInto(Cell) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- copyCellInto(Cell, int) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- copyCellIntoMSLAB(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- copyData(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context, Path, InputStream, Path, FSDataOutputStream, long) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- copyDeadServersSince(long) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Extract all the servers dead since a given time, and sort them.
- copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given byte[]
- copyFamilyTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the family to the given bytebuffer
- copyFields(StoreFileReader) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- copyFile(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context, SnapshotProtos.SnapshotFileInfo, Path) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- copyFiles(FileSystem, Path, FileSystem, Path, Configuration, ExecutorService, List<Future<Void>>) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- copyFilesParallel(FileSystem, Path, FileSystem, Path, Configuration, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyFrom(CompressionState) - Method in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- copyFrom(CompressionState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
-
- copyFrom(CompressionState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffCompressionState
-
- copyFromArrayToBuffer(ByteBuffer, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies the bytes from given array's offset to length part into the given buffer.
- copyFromArrayToBuffer(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies bytes from given array's offset to length part into the given buffer.
- copyFromBufferToArray(byte[], ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copies specified number of bytes from given offset of 'in' ByteBuffer to the array.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy one buffer's whole data to another.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy from one buffer to another from given offset.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy from one buffer to another from given offset.
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
Copy the state from the next one into this instance (the previous state placeholder).
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- copyFromNext(RowIndexSeekerV1.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
Copy the state from the next one into this instance (the previous state placeholder).
- copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy the given number of bytes from the given stream and put it at the current position of the
given buffer, updating the position in the buffer.
- copyHFileHalf(Configuration, Path, Path, Reference, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Copy half of an HFile into a new HFile.
- copyHFilesToStagingDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- CopyKeyDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Just copy data, do not do any kind of compression.
- CopyKeyDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- CopyKeyDataBlockEncoder.CopyKeyEncodingState - Class in org.apache.hadoop.hbase.io.encoding
-
- CopyKeyDataBlockEncoder.SeekerStateBufferedEncodedSeeker - Class in org.apache.hadoop.hbase.io.encoding
-
- CopyKeyEncodingState() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder.CopyKeyEncodingState
-
- copyKeyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
The position will be set to the beginning of the new ByteBuffer n * @return the Bytebuffer
containing the key part of the cell
- copyOfRange(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArrayList
- COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArraySet
- CopyOnWriteArrayMap<K,V> - Class in org.apache.hadoop.hbase.types
-
A Map that keeps a sorted array in order to provide the concurrent map interface.
- CopyOnWriteArrayMap() - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- CopyOnWriteArrayMap(Comparator<? super K>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- CopyOnWriteArrayMap(Comparator<? super K>, CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- CopyOnWriteArrayMap.ArrayEntryIterator<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayEntrySet<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayHolder<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayKeyIterator<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayKeySet<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayValueCollection<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.ArrayValueIterator<K,V> - Class in org.apache.hadoop.hbase.types
-
- CopyOnWriteArrayMap.COWEntry<K,V> - Class in org.apache.hadoop.hbase.types
-
- copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given byte[]
- copyQualifierTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the qualifier to the given bytebuffer
- copyQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- copyRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to a new byte[]
- copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given byte[]
- copyRowTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the row to the given bytebuffer
- copyServerNames() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- copySnapshotForScanner(Configuration, FileSystem, Path, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Copy the snapshot files for a snapshot scanner, discards meta changes.
- CopyTable - Class in org.apache.hadoop.hbase.mapreduce
-
Tool used to copy a table to another one which can be on a different setup.
- CopyTable() - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- copyTableCFs(Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- copyTableCFs() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- copyTableCFs(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- copyTableCFsMap(Map<TableName, List<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- copyTagsTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Copies the tags info into the tag portion of the cell
- copyTagsTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Copies the tags info into the tag portion of the cell
- copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyTagTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyToByteBuff(byte[], int, int, ByteBuff) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
- copyToChunkCell(Cell, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
out of it
- copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- copyToNewByteArray(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- copyToNewKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
copy the cell to create a new keyvalue
- copyToZipStream(File, ZipEntry, ZipOutputStream) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
- copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given byte[]
- copyValueTo(Cell, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the value to the given bytebuffer
- copyValueTo(Tag, byte[], int) - Static method in interface org.apache.hadoop.hbase.Tag
-
Copies the tag's value bytes to the given byte array
- copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- CORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- CoreCoprocessor - Annotation Type in org.apache.hadoop.hbase.coprocessor
-
Marker annotation that denotes Coprocessors that are core to HBase.
- corePoolSize - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- corePoolSize - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- corePoolSize - Variable in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- coreThreadPoolPrefix - Variable in class org.apache.hadoop.hbase.ChoreService
-
The coreThreadPoolPrefix is the prefix that will be applied to all threads within the
ScheduledThreadPoolExecutor.
- correctAssignments(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- corrupt - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.SplitWALResult
-
- CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- corrupted - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
- corrupted - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- CorruptedLogFileException(String) - Constructor for exception org.apache.hadoop.hbase.wal.WALSplitter.CorruptedLogFileException
-
- CorruptedLogFileException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.wal.WALSplitter.CorruptedLogFileException
-
CorruptedLogFileException with cause
- corruptedLogs - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- corruptedMobFiles - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- corruptedProcs - Variable in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Exception thrown when the found snapshot info from the filesystem is not valid.
- CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- CorruptedSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason.
- CorruptedWALProcedureStoreException - Exception in org.apache.hadoop.hbase.procedure2.store.wal
-
- CorruptedWALProcedureStoreException() - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
-
Deprecated.
default constructor
- CorruptedWALProcedureStoreException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
-
Deprecated.
Constructor
- CorruptHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
This exception is thrown when attempts to read an HFile fail due to corruption or truncation
issues.
- CorruptHFileException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- cost - Variable in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- cost - Variable in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- cost - Variable in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- cost - Variable in class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- cost() - Method in class org.apache.hadoop.hbase.master.balancer.TableSkewCostFunction
-
- cost - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- COST_EPSILON - Static variable in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- COST_FUNCTIONS_COST_FUNCTIONS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- CostFromRegionLoadAsRateFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Class to be used for the subset of RegionLoad costs that should be treated as rates.
- CostFromRegionLoadAsRateFunction() - Constructor for class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadAsRateFunction
-
- CostFromRegionLoadFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Base class the allows writing costs functions from rolling average of some number from
RegionLoad.
- CostFromRegionLoadFunction() - Constructor for class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- costFuncInfoList - Variable in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
-
- costFuncInfoList - Variable in class org.apache.hadoop.hbase.client.BalancerRejection
-
- CostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Base class of StochasticLoadBalancer's Cost Functions.
- CostFunction() - Constructor for class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- costFunctionDescs - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- costFunctions - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- costlyOperationTimer - Variable in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
-
- costPerGroup(Int2IntCounterMap) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
For each primary region, it computes the total number of replicas in the array (numReplicas)
and returns a sum of numReplicas-1 squared.
- costs - Variable in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- costsChanged - Variable in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- costsPerGroup - Variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- costsPerTable - Variable in class org.apache.hadoop.hbase.master.balancer.TableSkewCostFunction
-
- couldNotCommunicateWithServer - Variable in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- count - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- count - Variable in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- count - Variable in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- count - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- count - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- count - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- count - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Cache access count (sequential ID)
- count - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache access count (sequential ID)
- count - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- count - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- count - Variable in class org.apache.hadoop.hbase.mapreduce.SampleUploader.Uploader
-
- count - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- count - Variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- count - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- count - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- count - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
- count - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- count - Variable in class org.apache.hadoop.hbase.util.SimpleMovingAverage
-
- count - Variable in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Total number of items in stream
- COUNT_OF_ROWS_FILTERED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- COUNT_OF_ROWS_FILTERED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- COUNT_OF_ROWS_SCANNED_KEY - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- COUNT_OF_ROWS_SCANNED_KEY_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- countCurrentCol - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- countData - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- countDeletedFiles(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- countDistinctRowKeysAndHFiles(WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
Count the number of different row keys in the given edit because of mini-batching.
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.NoopLatch
-
- countDownChildren(RootProcedureState<TEnvironment>, Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- COUNTER - Static variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- Counter() - Constructor for enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
-
- Counter() - Constructor for enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
-
- Counter - Interface in org.apache.hadoop.hbase.metrics
-
A mutable number optimized for high concurrency counting.
- counter - Variable in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
-
- counter - Variable in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- counter(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- counter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Get or construct a
Counter
used to track a mutable number.
- Counter() - Constructor for enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
- Counter - Class in org.apache.hadoop.hbase.util
-
- Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- Counter(Counter.Cell) - Constructor for class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- counter - Variable in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- counter - Variable in class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
- Counter.Cell - Class in org.apache.hadoop.hbase.util
-
Deprecated.
- Counter.Container - Class in org.apache.hadoop.hbase.util
-
Deprecated.
- COUNTER_KEY - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- counterFactory - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- CounterImpl - Class in org.apache.hadoop.hbase.metrics.impl
-
Custom implementation of
Counter
using LongAdder.
- CounterImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.CounterImpl
-
- counters - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
Hash to hold the String -> Atomic Long mappings for each metric
- Counters() - Constructor for enum org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper.Counters
-
- Counters() - Constructor for enum org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper.Counters
-
- Counters() - Constructor for enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
- Counters() - Constructor for enum org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterMapper.Counters
-
- counters - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- countersMap - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from remote region servers
- countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from region servers
- countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of NotServingRegionException caught
- countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of regions
- countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns the count of active regionservers
- countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC calls
- countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC retries
- countOfRowsFiltered - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
number of rows filtered during scan RPC
- countOfRowsScanned - Variable in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
number of rows scanned during scan RPC.
- countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC calls
- countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC retries
- countPerRow - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- counts - Variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- COWEntry(K, V) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.COWEntry
-
- CP_COPROCESSOR_WHITELIST_PATHS_KEY - Static variable in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
- CP_HTD_ATTR_INCLUSION_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Pattern that matches a coprocessor specification.
- CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- cpEnv - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- cpHost - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- cpRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- crashedServer - Variable in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- crashedServer - Variable in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- crashedServer - Variable in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- crashedServer - Variable in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- crashedServer - Variable in class org.apache.hadoop.hbase.replication.regionserver.ClaimReplicationQueueCallable
-
- create(Configuration) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Create an archive tracker for the passed in server
- create(ZKWatcher, HFileArchiveTableMonitor) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Create an archive tracker with the special passed in table monitor.
- create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.CellBuilderFactory
-
Create a CellBuilder instance.
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
-
- create(Configuration, String, String, String, RegistryEndpointsRefresher.Refresher) - Static method in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.RequestControllerFactory
-
- create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- create() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- create(CellBuilderType) - Static method in class org.apache.hadoop.hbase.ExtendedCellBuilderFactory
-
Allows creating a cell with the given CellBuilderType.
- create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(ClientProtocol, String, FsPermission, String, EnumSetWritable<CreateFlag>, boolean, short, long, CryptoProtocolVersion[]) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.FileCreator
-
- create(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- create(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Initialize an
ByteBuffAllocator
which will try to allocate ByteBuffers from off-heap if
reservoir is enabled and the reservoir has enough buffers, otherwise the allocator will just
allocate the insufficient buffers from on-heap to meet the requirement.
- create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- create(Configuration, FileSystem, Path, RegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, RegionInfo, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink.
- create(Configuration, FileSystem, Path, String, String, String, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(String, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
- create(String, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
-
- create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue reading from in
- create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue reading length
from in
- create(String, String, String, long, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- create(String, String, String, long, KeyValue.Type, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
n * Where to read bytes from.
- create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue reading length
from in
nn * @return Created
KeyValue OR if we find a length of zero, we will return null which can be useful marking a
stream as done.
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
Deprecated.
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory
-
- create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
-
- create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactory
-
- create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
-
- create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
-
- create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
-
- create(MasterRegionParams) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- create(Server) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- create(String, Configuration, Abortable, FileSystem, Path, Path, String, long, long) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- create(ZKWatcher, Configuration, String) - Static method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryFactoryImpl
-
- create(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Create or return MetricRegistry with the given info.
- create(MetricRegistryInfo) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistryFactory
-
Create a MetricRegistry from the given MetricRegistryInfo
- create(FileSystem, Path, Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
- create(FileSystem, Path, Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.mob.MobFile
-
Creates an instance of the MobFile.
- create(byte[], String, String, String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
Creates an instance of MobFileName n * The md5 hex string of the start key.
- create(String, String, String, String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
Creates an instance of MobFileName n * The md5 hex string of the start key.
- create(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
Creates an instance of MobFileName.
- create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create() - Static method in class org.apache.hadoop.hbase.nio.RefCnt
-
Create an
RefCnt
with an initial reference count = 1.
- create(ByteBuffAllocator.Recycler) - Static method in class org.apache.hadoop.hbase.nio.RefCnt
-
- create(Configuration) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- create(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
- create() - Static method in class org.apache.hadoop.hbase.RawCellBuilderFactory
-
Returns the cell that is created
- create() - Static method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
-
Deprecated.
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Create the FlushPolicy configured for the given table.
- create(HRegionServer, RegionInfo, long, TableDescriptor, long) - Static method in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- create(HRegionServer, String, long, boolean, ServerName) - Static method in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
-
- create(ScanInfo, ScanType, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- create(Scan, ScanInfo, ColumnTracker, DeleteTracker, boolean, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
- create(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
-
- create(Scan, ScanInfo, NavigableSet<byte[]>, long, long, RegionCoprocessorHost) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Create the RegionSplitPolicy configured for the given table.
- create(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
Create the RegionSplitRestriction configured for the given table.
- create(Configuration, PriorityFunction, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- create(HStore, Configuration, CellComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine configured for the given Store.
- create(Configuration, boolean, StoreContext) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- create(Configuration, TableDescriptor, ColumnFamilyDescriptor, HRegionFileSystem) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
Used at master side when splitting/merging regions, as we do not have a Store, thus no
StoreContext at master side.
- create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
-
- create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
-
- create(TimeRangeTracker.Type) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- create(TimeRangeTracker.Type, TimeRangeTracker) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- create(TimeRangeTracker.Type, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- create(Configuration, String, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the
cellCodecClsName
and
CompressionContext, if
cellCodecClsName
is specified.
- create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the CompressionContext.
- create(Configuration, String) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceFactory
-
- create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
-
Wraps an underlying UserGroupInformation
instance.
- create(UserGroupInformation) - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Wraps an underlying UserGroupInformation
instance.
- create(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, ForeignExceptionSnare) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Return a SnapshotManifest instance, used for writing a snapshot.
- create(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, ForeignExceptionSnare, MonitoredTask) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- create() - Static method in class org.apache.hadoop.hbase.TagBuilderFactory
-
- create(TestingHBaseClusterOption) - Static method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
- create(Configuration) - Static method in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- create(Configuration, ExecutorService) - Static method in interface org.apache.hadoop.hbase.tool.Canary
-
- create(Configuration, ExecutorService, CanaryTool.Sink) - Static method in interface org.apache.hadoop.hbase.tool.Canary
-
- create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Create the specified file on the filesystem.
- create(Configuration, FileSystem, Path, FsPermission, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create() - Method in class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- create(A, B, C) - Static method in class org.apache.hadoop.hbase.util.Triple
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
NONSEQUENTIAL create is idempotent operation.
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CREATE_TABLE_CONF_KEY - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- CREATE_TIME_TS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- createACL(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- createACL(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- createACLTable(Admin) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
-
Create the ACL table n
- createActiveMasterManager(ZKWatcher, ServerName, Server) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Protected to have custom implementations in tests override the default ActiveMaster
implementation.
- createAddr(ServerName) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- createAdminServerStub(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- createAndFailSilent(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node, iff the node does not exist.
- createAndFailSilent(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node containing specified data, iff the node does not exist.
- createAndFailSilent(ZKWatcher, ZKUtil.ZKUtilOp.CreateAndFailSilent) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns a createAndFailSilent ZKUtilOp
- CreateAndFailSilent(String, byte[]) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- createAndGet(ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Creates the singleton instance, if not yet present, and returns the same.
- createAndPrepare(E) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
Deprecated.
- createAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node with the specified data and watches it.
- createAnother() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Creates another similar Bloom filter.
- createAssignmentManager(MasterServices, MasterRegion) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createAssignProcedure(RegionInfo, ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create an assign TransitRegionStateProcedure.
- createAssignProcedure(RegionStateNode, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create an assign TransitRegionStateProcedure.
- createAssignProcedures(List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create an array of TransitRegionStateProcedure w/o specifying a target server.
- createAssignProcedures(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- createAssignProcedures(MasterProcedureEnv, List<RegionInfo>, int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
Create assign procedures for the give regions, according to the regionReplication
.
- createAssignProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- createAssignProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- createAssignProceduresForOpeningNewRegions(MasterProcedureEnv, List<RegionInfo>, int, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- createAssignProceduresForSplitDaughters(MasterProcedureEnv, List<RegionInfo>, int, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- CreateAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
-
- createAsyncConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
- createAsyncConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new AsyncConnection instance using the passed conf
and user
.
- createAsyncRequestFuture(AsyncProcessTask, List<Action>, long) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- createAsyncWriter(Configuration, FileSystem, Path, boolean, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
Public because of AsyncFSWAL.
- createAsyncWriter(Configuration, FileSystem, Path, boolean, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Static method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
Public because of AsyncFSWAL.
- createBackReferenceName(String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create the back reference name
- createBackRefs - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- createBalanceRSGroupRequest(String, BalanceRequest) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupProtobufUtil
-
- createBaseZNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- createBatch(WALEntryStream) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- createBatches(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Divide the entries into multiple batches, so that we can replicate each batch in a thread pool
concurrently.
- createBatchPool(Configuration) - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
- createBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
-
- createBlockingLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
Creates a latch which blocks.
- createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- createBlockingRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Creates a "channel" that can be used by a blocking protobuf service.
- createBottomReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
n * @return A
Reference
that points at the bottom half of a an hfile
- createBucketCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
-
- createBuffers(int, ByteBufferAllocator) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
- createBuilder(HFileBlock, ByteBuff) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Creates a new HFileBlockBuilder from the existing block and a new ByteBuff.
- createBulkLoadEvent(RegionInfo, WALProtos.BulkLoadDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Create a bulk loader WALEdit
- createBySize(int, double, int, int, BloomType) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Creates a Bloom filter chunk of the given size.
- createByteArray(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Write KeyValue format into a byte array.
- createByteArray(byte[], int, int, byte[], int, int, Object, int, int, long, KeyValue.Type, Object, int, int, List<Tag>) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createCache() - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
Create a cache for region to list of servers
- createCacheConf(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Creates the cache config.
- createCall(int, BlockingService, Descriptors.MethodDescriptor, RPCProtos.RequestHeader, Message, CellScanner, long, InetAddress, int, RpcServer.CallCleanup) - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- createCall(int, BlockingService, Descriptors.MethodDescriptor, RPCProtos.RequestHeader, Message, CellScanner, long, InetAddress, int, RpcServer.CallCleanup) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- createCall(int, BlockingService, Descriptors.MethodDescriptor, RPCProtos.RequestHeader, Message, CellScanner, long, InetAddress, int, RpcServer.CallCleanup) - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- createCallable(ServerName, TableName, MultiAction) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Create a callable.
- createCaller(CancellableRegionServerCallable, int) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
Create a caller.
- createCandidateGenerators() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- createCandidateGenerators() - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- createCatalogReplicationSource(RegionInfo) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Create, initialize, and start the Catalog ReplicationSource.
- createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
-
- createCell(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
-
- createCell(byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
-
- createCell(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
-
- createCell(byte[], byte[], byte[], long, long) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- createCell(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns A new cell which is having the extra tags also added to it.
- createCell(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns A new cell which is having the extra tags also added to it.
- createCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createCell(Cell, List<Tag>) - Static method in interface org.apache.hadoop.hbase.RawCell
-
Returns A new cell which is having the extra tags also added to it.
- createCellReference(ByteBufferKeyValue, ByteBuffer, int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return CellScanner interface over cellIterables
- createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return CellScanner interface over cellIterable
- createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return CellScanner interface over cellIterable
or null if cells
is
null
- createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return CellScanner interface over cellArray
- createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Flatten the map of cells out under the CellScanner
- createCellScanner(Codec, CompressionCodec, byte[]) - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
Create a cell scanner.
- createCellScannerReusingBuffers(Codec, CompressionCodec, ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder
-
Create a cell scanner using an existing bytebuff.
- createCfRenameMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
- createChecksum(DFSClient) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createChunk(boolean, ChunkCreator.ChunkType, int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Creates the chunk either onheap or offheap
- createChunkCell(ByteBuffer, int, int, int, long) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- createChunkForPool(ChunkCreator.ChunkType, int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- createClassLoader(URL[]) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- createClassLoader(URL[], ClassLoader) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- createClassLoader(ClassLoader, Path) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- createCleanupScheduledChore(Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Creates a scheduled chore that is used to clean up old nonces.
- createClient(Configuration, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Helper method for tests only.
- createClient(Configuration, String, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
- createClient(Configuration, String, SocketAddress, MetricsConnection) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
- createClient(Configuration, InetAddress, SecurityInfo, Token<? extends TokenIdentifier>, boolean, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslClientAuthenticationProvider
-
- createClient(Configuration, InetAddress, SecurityInfo, Token<? extends TokenIdentifier>, boolean, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslClientAuthenticationProvider
-
- createClient(Configuration, InetAddress, SecurityInfo, Token<? extends TokenIdentifier>, boolean, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- createClient(Configuration, InetAddress, SecurityInfo, Token<? extends TokenIdentifier>, boolean, Map<String, String>) - Method in interface org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProvider
-
Creates the SASL client instance for this auth'n method.
- createClient(Configuration, InetAddress, SecurityInfo, Token<? extends TokenIdentifier>, boolean, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslClientAuthenticationProvider
-
- createClientSpan(String) - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
Create a span with SpanKind.CLIENT
.
- createCloseRowBefore(byte[]) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Create a row before the specified row and very close to the specified row.
- createClosestRowAfter(byte[]) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Create the closest row after the specified row
- createClosestRowAfter(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
Create the closest row after the specified row
- createCluster(List<ServerName>, Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying the ZooKeeper cluster key to the base
Configuration.
- createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying property overrides prefixed by a cluster
profile key to the base Configuration.
- createClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
-
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Creates an instance of a compaction context specific to this engine.
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- createCompaction(RegionInfo, WALProtos.CompactionDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Returns A Marker WALEdit that has c
serialized as its value
- createCompactionExecutors() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- createCompactionPolicy(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createCompactionRequest(ArrayList<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- createCompactionRequest(ArrayList<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- createCompactionRequest(ArrayList<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- createCompactor(Configuration, HStore) - Method in class org.apache.hadoop.hbase.mob.MobStoreEngine
-
Creates the DefaultMobCompactor.
- createCompactor(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
- createComparator(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- createComparator() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
- createCompareOperator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createCompletedResult() - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- createCompleteResult(Iterable<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Forms a single result from the partial results in the partialResults list.
- createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
-
- createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine's components.
- createComponents(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- createComponentsOnce(Configuration, HStore, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- createCompositeImmutableSegment(CellComparator, List<ImmutableSegment>) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createCompositeKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Creates a composite key to use as a mapper output key when using
MultiTableHFileOutputFormat.configureIncrementaLoad to set up bulk ingest job
- createCompositeKey(byte[], ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts an ImmutableBytesWritable for the suffix
- createCompositeKey(String, ImmutableBytesWritable) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
Alternate api which accepts a String for the tableName and ImmutableBytesWritable for the
suffix
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createCompressor() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- createConf(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- createConf() - Static method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Creates a new configuration and sets region mover specific overrides
- createConfigurationSubset() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using default HBaseConfiguration.
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Creates a cluster connection using the passed Configuration.
- createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Creates a cluster connection using the passed Configuration.
- createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Creates a cluster connection using the passed Configuration.
- createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Not connected.
- createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
-
Creates a connection.
- createConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- createConnection(Configuration) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- createConnection(Configuration) - Method in interface org.apache.hadoop.hbase.Server
-
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
- createContextName(String) - Static method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
From the name of the class that's starting up create the context that an IPC source should
register itself.
- createCostFunction(Class<? extends CostFunction>, Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- createCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
Create a new counter with the specified name n * @return
AtomicLong
instance for the
counter with counterName
- createCounter() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- createCounters(int) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- createCryptoAES(RPCProtos.CryptoCipherMeta, Configuration) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Helper to create an instance of CryptoAES.
- createCursor(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
-
- createCursorResult(Cursor) - Static method in class org.apache.hadoop.hbase.client.Result
-
- createDaughterRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Create daughter regions
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createDecompressor() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting input stream given a context and IV
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting output stream given an initialized decryptor
- createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Create a stream for decryption n
- createDeleteBloomAtWrite(Configuration, CacheConfig, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new Delete Family Bloom filter at the time of
HStoreFile
writing.
- createDeleteMutation(List<Cell>, BulkDeleteProtos.BulkDeleteRequest.DeleteType, Long) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- createDeletesForExistingNamespaceSnapshotSizes(Set<String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a list of Delete
to remove given namespace snapshot entries to removefrom quota
table
- createDeletesForExistingNamespaceSnapshotSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a list of Delete
to remove all namespace snapshot entries from quota table.
- createDeletesForExistingSnapshotsFromScan(Connection, Scan) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a list of Delete
to remove all entries returned by the passed scanner.
- createDeletesForExistingTableSnapshotSizes(Multimap<TableName, String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a list of Delete
to remove given table snapshot entries to remove from quota
table
- createDeletesForExistingTableSnapshotSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a list of Delete
to remove all table snapshot entries from quota table.
- createDestinationServersList(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Creates a list of possible destinations for a region.
- createDestinationServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- createDFSClientAdaptor() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Creates a directory.
- createDir(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- createDirectory(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
Create the namespace directory
- createDirIfNotExist(Path) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- createDirOnFileSystem(FileSystem, Configuration, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Creates a directory for a filesystem and configuration object.
- createdTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- createDummyStoppable() - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
- createEmptyByteArray(int, int, int, long, KeyValue.Type, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create an empty byte[] representing a KeyValue All lengths are preset and can be filled in
later.
- createEmptyContext() - Method in class org.apache.hadoop.hbase.client.NoOpRetryableCallerInterceptor
-
- createEmptyContext() - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- createEmptyContext() - Method in class org.apache.hadoop.hbase.client.RetryingCallerInterceptor
-
This returns the context object for the current call.
- createEmptyRequest(StripeCompactionPolicy.StripeInformationProvider, CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- createEmptyWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
Called if there are no cells for some stripe.
- createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- createEncryptionContext(Configuration, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Helper to create an encyption context.
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given a context and IV
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given an initialized encryptor
- createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Create a stream for encryption n
- createEncryptor(Configuration, HdfsFileStatus, DFSClient) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createEncryptor(Configuration, FileEncryptionInfo, DFSClient) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.TransparentCryptoHelper
-
- createEnvironment(C, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Called when a new Coprocessor class is loaded
- createEnvironment(MasterCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- createEnvironment(RegionCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- createEnvironment(RegionServerCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- createEnvironment(WALCoprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- createEphemeralNodeAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set the specified znode to be an ephemeral node carrying the specified data.
- createEphemeralZNode(String, byte[]) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Function to create EPHEMERAL ZNODE with given path and data as params.
- createEphemeralZNodeCallback - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Callback used while creating a Ephemeral ZNode tries to create ZNode again if Connection was
lost in previous try.
- createEventLoopPerClient(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
- createExceptionString(Class) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
-
- createExecutor(String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- createExecutor(Configuration, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- createExecutor(BlockingQueue<Runnable>, int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- createExecutorService() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- createExternalBlockcache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
-
- createFamilyBlockSizeMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Runs inside the task to deserialize column family to block size map from the configuration.
- createFamilyBloomParamMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Runs inside the task to deserialize column family to bloom filter param map from the
configuration.
- createFamilyBloomTypeMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Runs inside the task to deserialize column family to bloom filter type map from the
configuration.
- createFamilyCompressionMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Runs inside the task to deserialize column family to compression algorithm map from the
configuration.
- createFamilyConfValueMap(Configuration, String) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Run inside the task to deserialize column family to given conf value map.
- createFamilyDataBlockEncodingMap(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Runs inside the task to deserialize column family to data block encoding type map from the
configuration.
- createFileContext(Compression.Algorithm, boolean, boolean, Encryption.Context) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- createFileCreator() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createFileCreator2() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createFileCreator3() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createFileCreator3_3() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createFileScanners(Collection<HStoreFile>, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Creates file scanners for compaction.
- createFilesystemLayout(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Create regions in file system.
- createFileWithRetries(FileSystem, Path, FsPermission) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.FileLockCallable
-
Deprecated.
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Creating this filter by reflection, it is used by
ParseFilter
,
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
-
Given the filter's arguments it constructs the filter
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- createFinishTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- createFirstDeleteFamilyCellOnRow(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Create a Delete Family Cell for the specified row and family that would be smaller than all
other possible Delete Family KeyValues that have the same row and family.
- createFirstKeyCell(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
-
- createFirstLevelCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
-
- createFirstOnNextRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
- createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue that is smaller than all other possible KeyValues for the given row.
- createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a KeyValue that is smaller than all other KeyValues that are older than the passed
timestamp.
- createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be smaller than all
other possible KeyValues that have the same row,family,qualifier.
- createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be smaller than all
other possible KeyValues that have the same row, family, qualifier.
- createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be smaller than all
other possible KeyValues that have the same row, family, qualifier.
- createFirstOnRow(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be smaller than all
other possible KeyValues that have the same row, family, qualifier.
- createFirstOnRow(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be smaller than all
other possible KeyValues that have the same row, family, qualifier.
- createFirstOnRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Create a Cell that is smaller than all other possible Cells for the given Cell's row.
- createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRow(byte[], int, short, byte[], int, byte, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFirstOnRowCol(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and
passed qualifier.
- createFirstOnRowColTS(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
- createFirstOnRowFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createFlushContext(long, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createFlushWALEdit(RegionInfo, WALProtos.FlushDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- createForMigration(Configuration, String, boolean, StoreContext) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- createForTesting(RegionInfo, RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
- createForWal(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Attempt to use builder API via reflection to create a file with the given parameters and
replication enabled.
- createForWal(FileSystem, Path, boolean, int, short, long, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Attempt to use builder API via reflection to create a file with the given parameters and
replication enabled.
- createFromBuff(ByteBuff, boolean, long, int, HFileContext, ByteBuffAllocator) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Creates a block from an existing buffer starting with a header.
- createFromFileInfo(HFileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- createFromHFileLink(Configuration, FileSystem, Path, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink starting from a hfileLink name
- createFromMeta(DataInput, HFile.Reader) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Instantiates the correct Bloom filter class based on the version provided in the meta block
data.
- createFromMeta(DataInput, HFile.Reader, BloomFilterMetrics) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- createFsLayout(MasterProcedureEnv, TableDescriptor, List<RegionInfo>, CreateTableProcedure.CreateHdfsRegions) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Create region layout in file system.
- createFsLayout(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- createFsLayout(MasterProcedureEnv, TableDescriptor, List<RegionInfo>, CreateTableProcedure.CreateHdfsRegions) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- createGCRegionProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- createGCRegionProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- createGeneralBloomAtWrite(Configuration, CacheConfig, BloomType, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new general (Row or RowCol) Bloom filter at the time of
HStoreFile
writing.
- createGetNamespaceSnapshotSize(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a Get
to fetch the namespace's total snapshot size.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Create a key by concatenating multiple column values.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Create a key by concatenating multiple column values.
- createGson() - Static method in class org.apache.hadoop.hbase.util.GsonUtil
-
Create a builder which is used to create a Gson instance.
- createGsonWithDisableHtmlEscaping() - Static method in class org.apache.hadoop.hbase.util.GsonUtil
-
- createHandler(Configuration, UserProvider) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- createHandler(Configuration, UserProvider) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- createHDFSRegionDir(Configuration, RegionInfo, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Creates, flushes, and closes a new region.
- createHdfsRegions(MasterProcedureEnv, Path, TableName, List<RegionInfo>) - Method in interface org.apache.hadoop.hbase.master.procedure.CreateTableProcedure.CreateHdfsRegions
-
- createHeaderAndMessageBytes(Message, Message, int, List<ByteBuffer>) - Static method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- createHeaderAndMessageBytes(Message, Message, int, int) - Static method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- createHFileArchiveManager() - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
- createHFileContext(Path, FixedFileTrailer, Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- createHFileLinkName(RegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHFileLinkName(TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHistogram() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Create a host-and-port string
- createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL, boolean, RegionServerServices) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(Configuration, RegionInfo, FileSystem, Path, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Create a region under the given table directory.
- createHRegion(RegionInfo, Path, Configuration, TableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createIfZNodeNotExists(String) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Checks if given ZNode exists, if not creates a PERSISTENT ZNODE for same.
- createImmutableSegment(CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
create empty immutable segment for initializations This ImmutableSegment is used as a place
holder for snapshot in Memstore.
- createImmutableSegment(MutableSegment, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createImmutableSegment(Configuration, CellComparator, MemStoreSegmentsIterator, MemStoreLAB, int, MemStoreCompactionStrategy.Action, CompactingMemStore.IndexType) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createImmutableSegmentByCompaction(Configuration, CellComparator, MemStoreSegmentsIterator, int, CompactingMemStore.IndexType, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createImmutableSegmentByFlattening(CSLMImmutableSegment, CompactingMemStore.IndexType, MemStoreSizing, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createImmutableSegmentByMerge(Configuration, CellComparator, MemStoreSegmentsIterator, int, List<ImmutableSegment>, CompactingMemStore.IndexType, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createIncCallable() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Create a socket address
- createInitialFileSystemLayout() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Create initial layout in filesystem.
- createInputFile(FileSystem, FileSystem, Path, Set<Path>) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionInputFormat
-
Create the input file for the given directories to compact.
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createInputStream(InputStream) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createInputStream(InputStream, Decompressor) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createIO(MetricsIOWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Create a MetricsIOSource from a MetricsIOWrapper.
- createIO(MetricsIOWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createIterator(Segment) - Static method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- createJar(File, File) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
n *
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
n *
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRecordReader
-
- createKeyOnly(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a new KeyValue that only contains the key portion (the value is set to be null).
- createKeyOnlyCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createKeyValueFromInputStream(InputStream, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue reading from the raw InputStream.
- createKeyValueFromKey(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
n * @return A KeyValue made of a byte array that holds the key-only part.
- createKeyValueFromKey(ByteBuffer) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
n * @return A KeyValue made of a byte buffer that holds the key-only part.
- createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
nnn * @return A KeyValue made of a byte array that holds the key-only part.
- createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be larger than or
equal to all other possible KeyValues that have the same row, family, qualifier.
- createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a KeyValue that is last on the specified row id.
- createLastOnRow(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Create a Cell that is larger than all other possible Cells for the given Cell's row.
- createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createLastOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
- createLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
Create a latch if the client does not have async proc support.
- createLatch(int, int) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
Create a latch if the client does not have async proc support
- createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Create a lease and insert it to the map of leases.
- createLeaseManager() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createList(int) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- createLock - Variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- createLockedResource(LockedResourceType, String, LockAndQueue) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- createLockRetryCounterFactory(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Returns A retry counter factory configured for retrying lock file creation.
- createLog(int, int, int, ServerName, Throwable, long, boolean, String, int, int) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- createMasterLock(String, LockType, String) - Method in class org.apache.hadoop.hbase.master.locking.LockManager
-
- createMasterLock(TableName, LockType, String) - Method in class org.apache.hadoop.hbase.master.locking.LockManager
-
- createMasterLock(RegionInfo[], String) - Method in class org.apache.hadoop.hbase.master.locking.LockManager
-
- createMasterStub(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- createMasterThread(Configuration, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a max byte array with the specified max byte count
- createMemStoreCompactor(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- createMergedRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Create merged region.
- createMergedRegionInfo(RegionInfo[]) - Static method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Create merged region info by looking at passed in regionsToMerge
to figure what
extremes for start and end keys to use; merged region needs to have an extent sufficient to
cover all regions-to-merge.
- createMergeProcedure(RegionInfo...) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- createMetaEntries(MasterServices, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
Create entries in the
hbase:meta
for each provided
RegionInfo
.
- createMetaTableDescriptorBuilder(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- createMeter() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- createMigrationTableDescriptor(Configuration, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- createMiniBatch(int, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- createMissingCFsInMetaDuringUpgrade(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createMobRefCell(Cell, byte[], Tag) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Creates a mob reference KeyValue.
- createMobRefCell(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
- createMobRegionDirChecker(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Creates an instance of MobRegionDirChecker.
- createMobRegionInfo(TableName) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Creates a RegionInfo object for MOB data.
- createModelFromResults(Result[]) - Method in class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
-
- createModifiedVisExpression(List<Tag>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
n * - all the visibility tags associated with the current Cell
- createMoveRegionProcedure(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- createMutableSegment(Configuration, CellComparator, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- createMyEphemeralNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create a new namespace.
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- createNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Create a new Namespace.
- createNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- createNamespace(NamespaceDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Create a new Namespace.
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createNamespace(TNamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- createNamespaceAndTable(Admin) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
Invokes Admin#createNamespace and Admin#createTable to create a namespace with a table that has
one column-family.
- createNamespaceAndTable(Admin) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
Invokes Admin#createNamespace and Admin#createTable to create a namespace with a table that has
one column-family.
- createNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace.
- createNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- createNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- CreateNamespaceProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to create a new namespace.
- CreateNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- CreateNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- CreateNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- CreateNamespaceProcedureBiConsumer(String) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.CreateNamespaceProcedureBiConsumer
-
- createNamespaceTable(MasterServices) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- createNettyRpcServerPreambleHandler() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- createNettyServerRpcConnection(Channel) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerPreambleHandler
-
- createNewCellWithTags(Mutation, Cell, Cell) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- createNewCellWithTags(Mutation, Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- createNewReplicationInstance(Configuration, HRegionServer, FileSystem, Path, Path, WALFactory) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Load the replication executorService objects, if any
- createNewShipper(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- createNewShipper(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- createNewState(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- createNewWALReader(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- createNextOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Return a new cell is located following input cell.
- createNextOnRowCol(Cell, long, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- createNInputSplitsUniform(InputSplit, int) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Create n splits for one InputSplit, For now only support uniform distribution
- createNode(String, Long) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- createNodeFailure(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- createNodeIfNotExistsAndWatch(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode to be a persistent node carrying the specified data.
- createNodeIfNotExistsNoWatch(ZKWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode with the specified data but does not watch it.
- createNodeSuccess(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- createNonceKey(long, long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Create a NonceKey from the specified nonceGroup and nonce.
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
The org.apache.hadoop.fs.FilterFileSystem does not yet support createNonRecursive.
- createNonSequential(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- createNormalizerManager(Configuration, ZKWatcher, HMaster) - Static method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerFactory
-
- createObject(ClientProtocol, String, FsPermission, String, EnumSetWritable<CreateFlag>, boolean, short, long, CryptoProtocolVersion[]) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.FileCreator
-
- createObject(K) - Method in interface org.apache.hadoop.hbase.util.ObjectPool.ObjectFactory
-
Creates a new shared object associated with the given key
, identified by the
equals
method.
- createOldWalsCleaner(int) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- createOneAssignProcedure(RegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create one TransitRegionStateProcedure to assign a region w/o specifying a target server.
- createOneUnassignProcedure(RegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create one TransitRegionStateProcedure to unassign a region.
- createOnHeap() - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Initialize an
ByteBuffAllocator
which only allocate ByteBuffer from on-heap, it's
designed for testing purpose or disabled reservoir case.
- createOptionGroup() - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- createOrUpdate(NamespacesInstanceModel, UriInfo, Admin, boolean) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
- createOutput(FileSystem, Path, boolean, boolean, short, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Static method in class org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper
-
Create
FanOutOneBlockAsyncDFSOutput
for
DistributedFileSystem
, and a simple
implementation for other
FileSystem
which wraps around a
FSDataOutputStream
.
- createOutput(DistributedFileSystem, String, boolean, boolean, short, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createOutput(DistributedFileSystem, Path, boolean, boolean, short, long, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- createOutputPath(Path) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
Create the output folder and optionally set ownership.
- createOutputSinkAndEntryBuffers() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Setup the output sinks and entry buffers ahead of splitting WAL.
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createOutputStream(OutputStream, Compressor) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- createOutputStream(Configuration, FileSystem, Path, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
A helper method to create HFile output streams in constructors
- createParallelBatches(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- createParams(Compactor.FileDetails, boolean, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createPassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createPath(TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create an HFileLink relative path for the table/region/family/hfile location
- createPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Helper method to connect to a peer
- createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Creates a compression stream without any additional wrapping into buffering streams.
- createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- createPresplitTable(TableName, RegionSplitter.SplitAlgorithm, String[], Configuration) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
- createPriority() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- createProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Exposed for hooking with unit tests.
- createProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createProcessor() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- createProcessor() - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- createProtobufOutput() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Returns the protobuf represention of the model
- createProvider(String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- createProvider(Class<? extends WALProvider>, String) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createProviders(Configuration) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Loads server authentication providers from the classpath and configuration, and then creates
the SaslServerAuthenticationProviders instance.
- createPutForNamespaceSnapshotSize(String, long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a Put
for the namespace's total snapshot size.
- createPutForSnapshotSize(TableName, String, long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Put
to persist the current size of the
snapshot
with respect to the
given
table
.
- createPutForSpaceSnapshot(TableName, SpaceQuotaSnapshot) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Put
to store the given
snapshot
for the given
tableName
in
the quota table.
- createPutKeyValue(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Create a KeyValue with this objects row key and the Put identifier.
- createPutKeyValue(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Create a KeyValue with this objects row key and the Put identifier.
- createPutKeyValue(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Create a KeyValue with this objects row key and the Put identifier.
- createQuarantinePath(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Given a path, generates a new path to where we move a corrupted hfile (bad trailer, no
trailer).
- createQueueRowAccess() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- createQuotaSnapshotNotifier() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createQuotaTable() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- createRangeListFromRowKeyPrefixes(byte[][]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- createReader(ReaderContext, HFileInfo, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Method returns the reader given the specified arguments.
- createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Creates reader with cache configuration disabled
- createReader(FileSystem, Path, CacheConfig, boolean, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader(ReaderContext, CacheConfig) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- createReader(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the WAL.
- createReader(FileSystem, Path, CancelableProgressable, boolean) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, accept custom reader classes from conf.
- createReader(FileSystem, Path, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, accept custom reader classes from conf.
- createReaderContext(boolean, long, ReaderContext.ReaderType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- createReaderIgnoreCustomClass(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, ignore custom reader classes from conf.
- createRecord(String, UserMetrics.ClientMetrics, long, String) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- createRecord(ServerMetrics, RegionMetrics, long) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Builds a TableRecordReader.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat
-
- createRecords(ClusterMetrics) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- createRecordWriter(TaskAttemptContext, OutputCommitter) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- createRecoveredEditsWriter(TableName, byte[], long) - Method in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
-
- createRecoveredEditsWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Should be package-private, visible for recovery testing.
- createRecoveredEditsWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
If you already have a WALFactory, you should favor the instance method.
- createRecoveredHFileWriter(TableName, String, long, String, boolean) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- createRecycler(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- createReference(K, V) - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Create a reference associated with the given object
- createReference(K, V) - Method in class org.apache.hadoop.hbase.util.SoftObjectPool
-
- createReference(K, V) - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
-
- createRegion(MetricsRegionWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Create a MetricsRegionSource from a MetricsRegionWrapper.
- createRegion(MetricsRegionWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createRegion(Configuration, Path, TableDescriptor, RegionInfo, ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionDir(Configuration, RegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Create the region directory in the filesystem.
- createRegionEventDescriptorQualifier(WALProtos.RegionEventDescriptor.EventType) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- createRegionEventWALEdit(RegionInfo, WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- createRegionEventWALEdit(byte[], WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- createRegionForReopen(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- createRegionInfos(TableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
- createRegionInfosForHoles(List<Pair<RegionInfo, RegionInfo>>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
Create a new
RegionInfo
corresponding to each provided "hole" pair.
- createRegionLoad(HRegion, ClusterStatusProtos.RegionLoad.Builder, HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRegionLocationFinder(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- createRegionLocations(HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
- createRegionName(TableName, byte[], long, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- createRegionOnFileSystem(Configuration, FileSystem, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Create a new Region on file-system.
- createRegionPlans(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
Create all of the RegionPlan's needed to move from the initial cluster state to the desired
state.
- createRegions(Configuration, Path, TableDescriptor, RegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(ThreadPoolExecutor, Configuration, Path, TableDescriptor, RegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionServerStatusStub() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the current master from ZooKeeper and open the RPC connection to it.
- createRegionServerStatusStub(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the current master from ZooKeeper and open the RPC connection to it.
- createRegionServerStub(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- createRegionServerThread(Configuration, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createRegionSizeCalculator(RegionLocator, Admin) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRegionSpan(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- createRegionStateNode(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- createRegionVisitor(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- createRegistryForMasterCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryForRSCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryInfoForMasterCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryInfoForRegionCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryInfoForRSCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRegistryInfoForWALCoprocessor(String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- createRemoteException(RPCProtos.ExceptionResponse) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- createRemoteSpan(String, Context) - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
Create a span which parent is from remote, i.e, passed through rpc.
- createReorderingProxy(ClientProtocol, HFileSystem.ReorderBlocks, Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
- createReplicationEndpoint() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- createReplicationSinkManager(Connection) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- createReplicator(List<WAL.Entry>, int, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- createReportRegionStateTransitionRequest(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRequest(Connection, Set<String>, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- createRequest(Connection, TableDescriptor) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
-
- CreateRescanAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
-
- createRescanFailure() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- createRescanSuccess(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- createResource(PoolMap.PoolResourceSupplier<V>) - Static method in class org.apache.hadoop.hbase.util.PoolMap
-
- createResourceConfig(Configuration, HMaster) - Static method in class org.apache.hadoop.hbase.master.http.api_v1.ResourceConfigFactory
-
- createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- createRestoreTableDescriptor(TableDescriptor, String) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- createRetryCounter(Configuration) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
Get a retry counter for getting the backoff time.
- createRootDir - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- createRootDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- createRootDir - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
Whether to create a new root or data directory path.
- createRoundRobinAssignProcedures(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create round-robin assigns.
- createRoundRobinAssignProcedures(List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create round-robin assigns.
- createRoundRobinAssignProcedures(MasterProcedureEnv, List<RegionInfo>, int, List<ServerName>, boolean) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
Create round robin assign procedures for the given regions, according to the
regionReplication
.
- createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- createRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Creates a "channel" that can be used by a protobuf service.
- createRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler) - Static method in class org.apache.hadoop.hbase.ipc.RpcServerFactory
-
- createRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Static method in class org.apache.hadoop.hbase.ipc.RpcServerFactory
-
- createRpcServer(Server, RpcSchedulerFactory, InetSocketAddress, String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createRpcServer(Server, RpcSchedulerFactory, InetSocketAddress, String) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- createRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createRSGroupTable() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupStartupWorker
-
- createSaslAdaptor() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createSaslPropertiesForEncryption(String) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer.SaslPlainServerFactory
-
- createScanForNamespaceSnapshotSizes() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a scanner for all existing namespace snapshot entries.
- createScanForNamespaceSnapshotSizes(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a scanner for all namespace snapshot entries of the given namespace
- createScanForSpaceSnapshotSizes() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- createScanForSpaceSnapshotSizes(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- createScanFromConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets up a
Scan
instance, applying settings from the configuration property constants
defined in
TableInputFormat
.
- createScanFromCursor(Cursor) - Static method in class org.apache.hadoop.hbase.client.Scan
-
Create a new Scan with a cursor.
- createScanner(HStore, ScanInfo, List<StoreFileScanner>, ScanType, long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createScanner(HStore, ScanInfo, List<StoreFileScanner>, long, long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createScanner(ScanInfo, List<StoreFileScanner>, ScanType, Compactor.FileDetails, long) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.InternalScannerFactory
-
- createScanner(ScanInfo, List<StoreFileScanner>, ScanType, Compactor.FileDetails, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor.StripeInternalScannerFactory
-
- createScanner(Scan, ScanInfo, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets the MobStoreScanner or MobReversedStoreScanner.
- createScanner(Scan, ScanInfo, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createScanner(HStore, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
Creates the scanner for compacting the pipeline.
- createScanner(List<KeyValueScanner>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFlusher
-
Creates the scanner for flushing snapshot.
- createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
Will be called in moveToNextRegion to create ScannerCallable.
- createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
-
- createScannerCallable() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- createScanResultCache(Scan) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- createSeeker(HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Create a HFileBlock seeker which find KeyValues within a block.
- createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- createSeeker(HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
-
- createSeekerState() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- createSeekerState() - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerStateBufferedEncodedSeeker
-
- createSeekerState() - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerStateBufferedEncodedSeeker
-
- createSelector(String, TableName, ChoreService, IntSupplier) - Static method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSelectorFactory
-
Create a CatalogReplicaLoadBalanceReplicaSelector based on input config.
- createSequential(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- createSerialBatches(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- createServer(MetricsRegionServerWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Given a wrapper create a MetricsRegionServerSource.
- createServer(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createServer(SecretManager<TokenIdentifier>, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider
-
- createServer(SecretManager<TokenIdentifier>, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- createServer(SecretManager<TokenIdentifier>, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslServerAuthenticationProvider
-
- createServer(SecretManager<TokenIdentifier>, Map<String, String>) - Method in interface org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider
-
Creates the SaslServer to accept incoming SASL authentication requests.
- createServer(SecretManager<TokenIdentifier>, Map<String, String>) - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslServerAuthenticationProvider
-
- createServerErrorTracker() - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
Creates the server error tracker to use inside process.
- createServerErrorTracker() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Creates the server error tracker to use inside process.
- createServerManager(MasterServices, RegionServerList) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createServerSocket(int) - Method in class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
-
- createSetData(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set data into node creating node if it doesn't yet exist.
- createShortCircuitConnection(Configuration, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface, ConnectionRegistry) - Static method in class org.apache.hadoop.hbase.client.ServerConnectionUtils
-
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
- createSingleServerRequest(MultiAction, int, ServerName, Set<CancellableRegionServerCallable>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- createSnapshot(RegionStateNode, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- CreateSnapshot - Class in org.apache.hadoop.hbase.snapshot
-
This is a command line class that will snapshot a given table.
- CreateSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- createSocket(String, int) - Method in class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
-
- createSource(String, ReplicationPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- createSpan(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- createSpan(String) - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
Create a SpanKind.INTERNAL
span.
- createSpan(String, SpanKind) - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
Create a span with the given kind
.
- createSplitExcecutors() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- createSplitProcedure(RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- createSplitsDir(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Creates region split daughter directories under the table dir.
- createSplittingWalProcedures(MasterProcedureEnv, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- createSplitWALProcedures(List<FileStatus>, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
- createStagingDir(Path, User, TableName) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- createStagingDir(Path, User, String) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- createStagingDir(Path, User, TableName) - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- createStagingDir(Path, User, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- createStartKey(Scan, ScanInfo) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- createStartKeyFromRow(byte[], ScanInfo) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createStatus(String, boolean) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createStore() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
-
- createStoreConfiguration(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- createStoreDir(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Create the store directory for the specified family name
- createStoreEngine(HStore, Configuration, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Creates the mob store engine.
- createStoreEngine(HStore, Configuration, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Creates the store engine configured for the given Store.
- createStoreFileAndReader(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- createStoreFileAndReader(StoreFileInfo) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- createStoreFileTracker(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- CreateStoreFileWriterParams - Class in org.apache.hadoop.hbase.regionserver
-
- CreateStoreFileWriterParams() - Constructor for class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- createStoreFlusher(Configuration, HStore) - Method in class org.apache.hadoop.hbase.mob.MobStoreEngine
-
- createStoreFlusher(Configuration, HStore) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createStreamReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayMap
-
- createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkMap
-
- createSubCellFlatMap(int, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
n * @return the JobConf n
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
Sets up the actual job.
- createSubmittableJob(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
This is separated from execution so that we can detect and handle the case where the
subprocedure is invalid and inactionable due to bad info (like DISABLED snapshot type being
sent here) nnn
- createSubstitution(MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- Creation of the
ImmutableSegment either by merge or copy-compact of the segments of the pipeline, based on the
Compactor Iterator.
- createSystemTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createSystemTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a system table using the given table definition.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table.
- createTable(TableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with the specified number of regions.
- createTable(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- createTable(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- createTable(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- createTable(TableName, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- createTable(Admin, TableName, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- createTable(TableDescriptor, byte[][], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createTable(TableDescriptor, byte[][], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a table using the given table definition.
- createTable(String, MetricsTableWrapperAggregate) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Create a MetricsTableSource from a MetricsTableWrapper.
- createTable(String, MetricsTableWrapperAggregate) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- createTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createTable(TableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createTable(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createTable(TTableDescriptor, List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- createTable(TableName, Path, Admin) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
If the table is created for the first time, then "completebulkload" reads the files twice.
- createTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- createTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createTableAsync(TableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- createTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new TableDescriptor in HDFS.
- createTableDescriptor(TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new TableDescriptor in HDFS.
- createTableDescriptorForTableDirectory(Path, TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create a new TableDescriptor in HDFS in the specified table directory.
- createTableDescriptorForTableDirectory(FileSystem, Path, TableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create a new TableDescriptor in HDFS in the specified table directory.
- createTableDirectories(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- CreateTableFuture(HBaseAdmin, TableDescriptor, byte[][], MasterProtos.CreateTableResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.CreateTableFuture
-
- createTableMetrics(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- createTableNameIfNecessary(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
-
Check that the object does not exist already.
- CreateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- CreateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, TableDescriptor, RegionInfo[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, TableDescriptor, RegionInfo[], ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure.CreateHdfsRegions - Interface in org.apache.hadoop.hbase.master.procedure
-
- CreateTableProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.CreateTableProcedureBiConsumer
-
- createTableStartTime - Variable in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- createTableTimer - Variable in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
This is the Timer metric object to keep track of the current count across invocations
- createTask(BufferedMutatorImpl.QueueRowAccess) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- createTaskFilter(String) - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Create a task filter according to a given filter type.
- createTaskIfAbsent(String, SplitLogManager.TaskBatch) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
nn * @return null on success, existing task on error
- createTempName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate a unique temporary Path.
- createTempName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate a unique temporary Path.
- createThreadPool(Configuration) - Method in class org.apache.hadoop.hbase.tool.HFileContentValidator
-
- createThreadPool(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- createThriftMetrics(Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- createThriftMetrics(Configuration) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- createThriftOneSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
Create a Source for a thrift one server
- createThriftOneSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
-
- createThriftTwoSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
Create a Source for a thrift two server
- createThriftTwoSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
-
- createTime - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- createTimer() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
n * @return A
Reference
that points at top half of a an hfile
- createTransparentCryptoHelper() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createTransparentCryptoHelperWithHDFS12396() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createTransparentCryptoHelperWithoutHDFS12396() - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createTServlet(TProtocolFactory) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Create a Servlet for the http server
- createUgiForRemoteUser(String) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler
-
- createUnassignProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- createUnassignProcedures(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- createUnassignProceduresForClosingExcessRegionReplicas(TableName, int) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Called by ModifyTableProcedures to unassign all the excess region replicas for a table.
- createUnassignProceduresForDisabling(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Called by DisableTableProcedure to unassign all the regions for a table.
- createUnassignProceduresForSplitOrMerge(MasterProcedureEnv, Stream<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Removes the single quote escaping a single quote - thus it returns an unescaped argument
- createUser(RPCProtos.ConnectionHeader) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- createUser(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Create a MetricsUserSource from a user
- createUser(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
-
Generates a new User
instance specifically for use in test code.
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Create a user for testing.
- createUserLoad(String, MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
n *
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
n *
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRecordReader
-
- createVisibilityExpTags(String) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Convert visibility expression into tags to be serialized.
- createVisibilityExpTags(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- createVisibilityExpTags(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates tags corresponding to given visibility expression.
- createVisibilityExpTags(String, boolean, boolean, Set<Integer>, VisibilityLabelOrdinalProvider) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- createVisibilityLabelFilter(Region, Authorizations) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- createWAL(WALFactory, MasterRegionWALRoller, String, FileSystem, Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- createWAL() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- createWAL() - Method in class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
-
- createWAL() - Method in class org.apache.hadoop.hbase.wal.FSHLogProvider
-
- createWALDir - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- createWALDir(boolean) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- createWALDir - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
Whether to create a new WAL directory.
- createWALWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a writer for the WAL.
- createWALWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
If you already have a WALFactory, you should favor the instance method.
- createWebAppContext(String, Configuration, AccessControlList, String) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
- createWithoutViolation(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
- createWithParents(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWithParents(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, String, Path, long, Compression.Algorithm, String, CacheConfig, Encryption.Context, boolean, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Creates a writer for the mob file in temp directory.
- createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, MobFileName, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Creates a writer for the mob file in temp directory.
- createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, ChecksumType, int, int, BloomType, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Creates a writer for the mob file in temp directory.
- createWriter(Configuration, FileSystem, ColumnFamilyDescriptor, Path, long, Compression.Algorithm, CacheConfig, Encryption.Context, ChecksumType, int, int, BloomType, boolean, Consumer<Path>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Creates a writer for the mob file in temp directory.
- createWriter() - Method in interface org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
-
- createWriter(InternalScanner, Compactor.FileDetails, boolean, boolean, Consumer<Path>) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSinkFactory
-
- createWriter(Compactor.FileDetails, boolean, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Creates a writer for a new file.
- createWriter(Compactor.FileDetails, boolean, String, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createWriter(Date, long, Compression.Algorithm, byte[], boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Creates the writer for the mob file in the mob family directory.
- createWriter(CreateStoreFileWriterParams) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create a writer for writing new store files.
- createWriter(CreateStoreFileWriterParams) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Create a writer for writing new store files.
- createWriter(CreateStoreFileWriterParams) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- createWriter(MemStoreSnapshot, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFlusher
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- createWriter(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.wal.FSHLogProvider
-
Public because of FSHLog.
- createWriter(Configuration, FileSystem, Path, boolean, long) - Static method in class org.apache.hadoop.hbase.wal.FSHLogProvider
-
Public because of FSHLog.
- createWriter(Path) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- createWriterFactory(MemStoreSnapshot, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This method allows subclasses to inject different writers without having to extend other
methods like rollWriter().
- createWriterInTmp(Date, long, Compression.Algorithm, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Creates the writer for the mob file in temp directory.
- createWriterInTmp(String, Path, long, Compression.Algorithm, byte[], boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Creates the writer for the mob file in temp directory.
- createWriterInTmp(MobFileName, Path, long, Compression.Algorithm, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Creates the writer for the mob file in temp directory.
- createWriterWithStoragePolicy(String) - Method in interface org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
-
- createWriteTable(int) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- createZKConnection(Watcher) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Creates Connection with ZooKeeper.
- createZNode(String, byte[]) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Function to create PERSISTENT ZNODE with given path and data given as params
- createZNodeCallback - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Callback used while creating a Persistent ZNode tries to create ZNode again if Connection was
lost in previous try.
- createZNodeRetryCounterFactory - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- createZnodeRetryCounterFactory(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Returns A retry counter factory configured for retrying znode creation.
- createZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- creationTime - Variable in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CRYPTO_AES_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- CRYPTO_AES_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
- CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto algorithm provider, a class name
- CRYPTO_ENABLED_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default value for globally enable / disable column family encryption (set to "true" for
backward compatibility)
- CRYPTO_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for globally enable / disable column family encryption
- CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm used for creating jks key, a string
- CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default behaviour is not to fail if the hash algorithm configured differs from the one used in
the HFile.
- CRYPTO_KEY_FAIL_ON_ALGORITHM_MISMATCH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for specifying the behaviour if the configured hash algorithm differs from
the one used for generating key hash in encrypted HFiles currently being read.
- CRYPTO_KEY_HASH_ALGORITHM_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Default hash algorithm used for generating key hash in encrypted HFiles.
- CRYPTO_KEY_HASH_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Configuration key for the hash algorithm used for generating key hash in encrypted HFiles.
- CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider, a class name
- CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider parameters
- CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate master key for the cluster, a string
- CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master key for the cluster, a string
- CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm to use when encrypting the WAL, a string
- CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master WAL encryption key for the cluster, a string
- CryptoAES - Class in org.apache.hadoop.hbase.io.crypto.aes
-
AES encryption and decryption.
- CryptoAES(String, Properties, byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
-
- cryptoAES - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- cryptoAES - Variable in class org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
-
- cryptoAES - Variable in class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
-
- cryptoAES - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- CryptoAES.Integrity - Class in org.apache.hadoop.hbase.io.crypto.aes
-
Helper class for providing integrity protection.
- cryptoAesEnable - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- CryptoAESUnwrapHandler - Class in org.apache.hadoop.hbase.security
-
Unwrap messages with Crypto AES.
- CryptoAESUnwrapHandler(CryptoAES) - Constructor for class org.apache.hadoop.hbase.security.CryptoAESUnwrapHandler
-
- CryptoAESWrapHandler - Class in org.apache.hadoop.hbase.security
-
wrap messages with Crypto AES.
- CryptoAESWrapHandler(CryptoAES) - Constructor for class org.apache.hadoop.hbase.security.CryptoAESWrapHandler
-
- cryptoByteStream - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Underlying stream to write encrypted bytes to
- CryptoCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- CryptoCipherProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- cryptoContext - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Encryption algorithm and key used
- cryptoContext - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Crypto context
- cryptoInputStream - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- cryptoOutputStream - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- CRYPTOSTREAM_BUFFERSIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- CSLMImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
- CSLMImmutableSegment(Segment, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
-
------------------------------------------------------------------------ Copy C-tor to be used
when new CSLMImmutableSegment is being built from a Mutable one.
- csm - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ctrl - Variable in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- ctrlAltAndCharacter(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- ctrlAndCharacter(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- ctx - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- ctx - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFile
-
- ctx - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- ctx - Variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- cTypes - Variable in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
-
- cur - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- cur_worker_name - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- curBlock - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- curBlockCacheSize - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- curBlockCacheUsed - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- curBuf - Variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- CurCall - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is set to Call object before Handler invokes an RPC and ybdie after the call returns.
- curColCell - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- curFamily - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- curFamilyMaxVersions - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- curFunctionCosts - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- curIndex - Variable in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- curInlineChunk - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Current leaf-level chunk.
- curItem - Variable in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- curItemIndex - Variable in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- curMemStoreSize - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- curMemStoreUsed - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- curOverallCost - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- curQualifier - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- curQualMetVersions - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- currChunk - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- current() - Method in interface org.apache.hadoop.hbase.CellScanner
-
Returns the current Cell which may be mutable
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- current - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- current - Variable in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
-
- current() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
-
- current - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- current - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- current - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCachesIterator
-
- current - Variable in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- current - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
The current sub-scanner, i.e.
- current - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- current - Variable in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- current - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- current - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
- current - Variable in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CURRENT_INSTANCE - Static variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- currentAverage - Variable in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
-
- currentBandwidth - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- currentBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- currentBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- currentBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- currentBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- currentCallable - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- currentClientHasMinimumVersion(int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the completed count of key values in currently running compaction
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- currentCompareRowInPeerTable - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- currentComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- CurrentCoprocessorMethods - Class in org.apache.hadoop.hbase.tool.coprocessor
-
- CurrentCoprocessorMethods() - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods
-
- currentCount - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- currentEntry - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- currentEntry - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- currentFamily - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentFamilyName - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentHour - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider.Tick
-
- CurrentHourProvider - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- CurrentHourProvider() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- CurrentHourProvider.Tick - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- currentIndexPosition - Variable in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
- currentKey - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- currentKey - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- currentKey - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- currentlyWriting - Variable in class org.apache.hadoop.hbase.wal.EntryBuffers
-
- currentMode - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- currentMode - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- currentParallelPutCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
Use this counter to track concurrent puts.
- currentPath - Variable in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- currentPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- currentPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- currentPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- currentPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- currentPos - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- currentPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- currentPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- currentPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- currentPosition - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- currentPosition - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- currentPosition - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- currentPosition - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- currentPositionOfEntry - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- currentPositionOfReader - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- currentProcessingCount - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- currentQualifier - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentQualifierName - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentQueueLimit - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- currentQuotaSnapshots - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- currentReader - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- currentRegion - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- currentRegionScanner - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- currentReturnCode - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- currentRow - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
-
- currentRow - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.CellScanner
-
- currentRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Row the query is on
- currentRow() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns a cell represent the current row
- currentRowCount - Variable in class org.apache.hadoop.hbase.AsyncMetaTableAccessor.MetaTableScanResultConsumer
-
- currentRowKey - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentRowQualifierName - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- currentRowResult - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.CellScanner
-
- currentRSToRegionMap - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
the regionServer to region map
- currentRunningState - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- currentScan - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- currentScannerCallable - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- currentScanners - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- currentScreenView - Variable in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- currentSnapshots - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- currentSortField - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- currentSourceHash - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- currentSqrSum - Variable in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
- currentSum - Variable in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
- currentTask - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- currentTerm - Variable in class org.apache.hadoop.hbase.util.LossyCounting
-
- currentThreadInFastFailMode() - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
Checks to see if the current thread is already in FastFail mode for *some* server.
- currentTime - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
-
Returns the currentTime.
- currentTime() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
-
Returns the currentTime.
- currentTime() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Returns the currentTime.
- currentTime() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- currentTrailerSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- currentVersion - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- currentVersions - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- currentWorkers - Variable in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- currentWriteBufferSize - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- currentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- currentWriter - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- currentWriterEndKey - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- currKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- currMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- currMemstoreTSLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- curRowBytes - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- curRowCols - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- curRowKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- currSize - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- currTagsLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- currValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- cursor() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Get the scan cursor if available.
- cursor - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- cursor() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- Cursor - Class in org.apache.hadoop.hbase.client
-
- Cursor(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Cursor
-
- cursor - Variable in class org.apache.hadoop.hbase.client.Result
-
- cursor - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- cursor(boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- cursorColumn - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- cursorPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- CursorPosition - Class in org.apache.hadoop.hbase.hbtop.terminal
-
A 2-d position in 'terminal space'.
- CursorPosition(int, int) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
-
- cursorRow - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- cursorVisible - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- curTaskZKVersion - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- curTotalNonRootEntrySize - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
The offset of the next entry to be added, relative to the end of the "secondary index" in the
"non-root" format representation of this index chunk.
- curTotalRootSize - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
The accumulated size of this chunk if stored in the root index format.
- CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
Custom RPC Controller factory allows frameworks to change the RPC controller.
- CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CUSTOM_HEADER_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- CUSTOM_METHODS_TO_IGNORE_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- CUSTOM_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
- CUSTOM_RPC_SERVER_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcServerFactory
-
- CUSTOM_TAG_TYPE_RANGE - Static variable in interface org.apache.hadoop.hbase.Tag
-
Custom tags if created are suggested to be above this range.
- customHeader - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.HTTPThriftClientBuilder
-
- customize(int, long, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
Used by CP users for customizing max versions, ttl and keepDeletedCells.
- customize(int, long, KeepDeletedCells, int, long) - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
Used by CP users for customizing max versions, ttl, keepDeletedCells, min versions, and time to
purge deletes.
- CustomizedScanInfoBuilder - Class in org.apache.hadoop.hbase.regionserver
-
Helper class for CP hooks to change max versions and TTL.
- CustomizedScanInfoBuilder(ScanInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- CustomizedScanInfoBuilder(ScanInfo, Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- customSFT - Variable in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- cyclePushSize - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
- cycles - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Cycles on same state.
- cycleStartTick - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
- g - Variable in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles.SampleItem
-
Difference between the lowest possible rank of the previous item, and the lowest possible
rank of this item.
- Gauge<T> - Interface in org.apache.hadoop.hbase.metrics
-
A metrics which measures a discrete value.
- GB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
-
- gc() - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- gcCount - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor.GcTimes
-
- GCMergedRegionsProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
- GCMergedRegionsProcedure(MasterProcedureEnv, RegionInfo, RegionInfo, RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- GCMergedRegionsProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- GCMultipleMergedRegionsProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
GC regions that have been Merged.
- GCMultipleMergedRegionsProcedure(MasterProcedureEnv, RegionInfo, List<RegionInfo>) - Constructor for class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- GCMultipleMergedRegionsProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- GCRegionProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
GC a Region that is no longer in use.
- GCRegionProcedure(MasterProcedureEnv, RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- GCRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- gcTimeMillis - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor.GcTimes
-
- GcTimes(GarbageCollectorMXBean) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor.GcTimes
-
- GcTimes(long, long) - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor.GcTimes
-
- genAssignmentPlan(TableName, SnapshotOfRegionAssignmentFromMeta, Map<String, Map<String, Float>>, FavoredNodesPlan, boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Generate the assignment plan for the existing table nnnn * @param
munkresForSecondaryAndTertiary if set on true the assignment plan for the tertiary and
secondary will be generated with Munkres algorithm, otherwise will be generated using
placeSecondaryAndTertiaryRS n
- GENERAL_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- GENERAL_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- generalBloomFilterWriter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- generalBloomMetaHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- generalBloomMetaMissCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- generalizedSeek(boolean, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLoadPicker
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLocalityPicker
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.LoadCandidateGenerator
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCandidateGenerator
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RandomCandidateGenerator
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaCandidateGenerator
-
- generate(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaRackCandidateGenerator
-
- generateCallInfoMap() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- generateChecksums(byte[], int, int, byte[], int, ChecksumType, int) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Generates a checksum for all the data in indata.
- generateClientId() - Static method in class org.apache.hadoop.hbase.client.ClientIdGenerator
-
Returns a unique ID incorporating IP address, PID, TID and timer.
- generateCompactionRequest(ArrayList<HStoreFile>, CompactionWindow, boolean, boolean, int, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- generateDeadServersListToSend() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Create the dead server to send.
- generateExceptionForChecksumFailureForTest(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Mechanism to throw an exception in case of hbase checksum failure.
- generateExceptions - Static variable in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
This is used by unit tests to make checksum failures throw an exception instead of returning
null.
- generateFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateFavoredNodes(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateFavoredNodesForDaughter(List<ServerName>, RegionInfo, RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- generateFavoredNodesForDaughter(List<ServerName>, RegionInfo, RegionInfo, RegionInfo) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
-
- generateFavoredNodesForDaughter(List<ServerName>, RegionInfo, RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- generateFavoredNodesForMergedRegion(RegionInfo, RegionInfo[]) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- generateFavoredNodesForMergedRegion(RegionInfo, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.favored.FavoredNodesPromoter
-
- generateFavoredNodesForMergedRegion(RegionInfo, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- generateFavoredNodesRoundRobin(Map<ServerName, List<RegionInfo>>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateFNForRegionsWithoutFN(FavoredNodeAssignmentHelper, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- generateGroupAssignments(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- generateHashCode(TableName, byte[], byte[], long, int, boolean, byte[]) - Static method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- generateJsonQuotaSummary(Iterable<Map.Entry<String, Map.Entry<Long, Long>>>, String) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
Summarizes the usage and limit for many targets (table or namespace) into JSON.
- generateMissingFavoredNode(List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateMissingFavoredNode(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateMissingFavoredNodeMultiRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateMissingFavoredNodeMultiRack(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateMissingFavoredNodeSingleRack(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- generateMonitorTables(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
Returns List of tables to use in test.
- generateMutableSegment(Configuration, CellComparator, MemStoreLAB, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- generateNewScannerId() - Method in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
-
- generatePartitions(Path) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- generateSecretKey(Configuration, String, String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- generateSecretKey(Configuration, String, byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA384 key derivation algorithm at 10,000 iterations.
- generateSecretKey(String, int, char[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a key (byte array) derived from the supplied password argument using the given algorithm
with a random salt at 10,000 iterations.
- generateSnapshotToRestoreDirMapping(Collection<String>, Path) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Generate a random path underneath baseRestoreDir for each snapshot in snapshots and return a
map from the snapshot to the restore directory.
- generateTicket() - Method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- generateTmpBytes(int) - Method in class org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator
-
- generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- generateUniqTempDir(boolean) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- generateUniqueName(String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate a unique file name, used by createTempName() and commitStoreFile()
- generator - Variable in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- generatorThread() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- GeneratorType() - Constructor for enum org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer.GeneratorType
-
- get(Get) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Extracts certain cells from the given rows, in batch.
- get(Get) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- get(CompletableFuture<T>) - Static method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- get(ChannelHandlerContext, FullHttpRequest) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor n
- Get(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.AbortProcedureFuture
-
- get(Future<T>, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Do a get with a timeout against the passed in future
.
- get() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
-
- get(Get, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- get() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get() - Static method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
Get the singleton nonce generator.
- get(Get, int) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- get(Get) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- get() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- get - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts specified cells from the given rows, as a batch.
- get() - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- get() - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
- get() - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- get() - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
-
- get(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- get(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Get the value of the name
.
- get(String) - Method in interface org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfigMap
-
- get(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- get(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- get(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- get(int) - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
- get(int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
Gets the RowRange at the given offset.
- get(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a new HFileSystem object, similar to FileSystem.get().
- get(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- get(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- get(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get(short) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- get() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- get(int) - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufferOutputStreamSupplier
-
- get(int) - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufOutputStreamSupplier
-
- get(int) - Method in interface org.apache.hadoop.hbase.ipc.CellBlockBuilder.OutputStreamSupplier
-
- get() - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
- get(TracingProtos.RPCTInfo, String) - Method in class org.apache.hadoop.hbase.ipc.RPCTInfoGetter
-
- get() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- get() - Method in interface org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter
-
- get(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- get() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- get(Get) - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
The design for master region is to only load all the data to memory at once when starting, so
typically you should not use the get method to get a single row of data at runtime.
- get(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- get(Table, String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- get() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer.ZKData
-
- get(Table, Get) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- get(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- get(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- get(K) - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- get(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns the MetricRegistry if found.
- get(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Returns previously registered metric with the name if any.
- get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Get singleton instance.
- get() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskAndWeakRefPair
-
- get() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
A relative method that returns byte at the current position.
- get(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the byte at the given index.
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the specified number of bytes from this ByteBuff's current position to the byte[]'s
offset.
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the specified number of bytes from this ByteBuff's given position to the byte[]'s
offset.
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the content from this ByteBuff's current position to the byte array and fills it.
- get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the content from this ByteBuff to a ByteBuffer Note : This will advance the position
marker of out
but not change the position maker for this ByteBuff
- get(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the byte at the given index.
- get() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
A relative method that returns byte at the current position.
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the content from this MBB's current position to the byte array and fills it.
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the specified number of bytes from this MBB's current position to the byte[]'s offset.
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies the content from an this MBB to a ByteBuffer
- get() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get(byte[]) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- get() - Method in class org.apache.hadoop.hbase.procedure2.trace.ProcedureSpanBuilder
-
- get(Connection, Configuration, FileSystem, TableName) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactory
-
- get(Connection, Configuration, FileSystem, TableName) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- get() - Static method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- get() - Static method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- get(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- get(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Get, boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFileWriterCreationTracker
-
- get - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
True if we are doing a 'Get' Scan.
- get(Get) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(Get, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get data from a table.
- get(Get, HRegion, RSRpcServices.RegionScannersCloseCallBack, RpcCallContext) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- get - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- get(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ExistsResource
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for GET namespace description or GET list of namespace tables.
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
-
Build a response for a list of all namespaces request.
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RegionsResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
-
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Build a response for a version request.
- get(String) - Method in class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- get() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- get() - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
-
- get() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- get(Size.Unit) - Method in class org.apache.hadoop.hbase.Size
-
get the value which is converted to specified unit.
- get(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Returns TableDescriptor for tablename
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling of
the qualifier.
- get(Get) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- get(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- get(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the node that matches the specified key or null in case of node not found.
- get(int, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Check if bit at specified index is 1.
- get(int) - Method in class org.apache.hadoop.hbase.util.ByteArrayHashKey
-
- get() - Method in interface org.apache.hadoop.hbase.util.ByteBufferUtils.ByteVisitor
-
Deprecated.
- get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the byte at index
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Get the data from the Bytes.
- get() - Method in interface org.apache.hadoop.hbase.util.ConcurrentMapUtils.IOExceptionSupplier
-
- get() - Method in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- get() - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- get(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Get the current table descriptor for the given table, or null if none exists.
- get(Future<T>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
A helper class for getting the result of a Future, and convert the error to an
IOException
.
- get(Future<T>, long, TimeUnit) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
A helper class for getting the result of a Future, and convert the error to an
IOException
.
- get(int) - Method in class org.apache.hadoop.hbase.util.HashKey
-
Return The byte at the given position in this HashKey
- get(K) - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Returns a shared object associated with the given key
, which is identified by the
equals
method.
- get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.PoolResourceSupplier
-
- get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range.
- get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from position
.
- get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from the current position
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int) - Method in class org.apache.hadoop.hbase.util.RowBloomHashKey
-
- get(int) - Method in class org.apache.hadoop.hbase.util.RowColBloomHashKey
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get() - Method in class org.apache.hadoop.hbase.util.SortedList
-
Returns a reference to the unmodifiable list currently backing the SortedList.
- get(int) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- get(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- get() - Method in class org.apache.hadoop.hbase.zookeeper.InstancePending
-
- get(String) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- get(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a metric by name
- get25thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 25th percentile in the distribution.
- get75thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get75thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 75th percentile in the distribution.
- get90thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 90th percentile in the distribution.
- get95thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get95thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 95th percentile in the distribution.
- get98thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get98thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 98th percentile in the distribution.
- get999thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get999thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 99.9th percentile in the distribution.
- get99thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get99thPercentile() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the value at the 99th percentile in the distribution.
- GET_DEFAULT_HOST_METHOD - Static variable in class org.apache.hadoop.hbase.util.DNS
-
- GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- GET_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- GET_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- getAbortable() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getAbortNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator or member to trigger an abort of
the global barrier acquisition or execution in subprocedures.
- getAbortZNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbortZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbsoluteIndex(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getAbsoluteOffset(int) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection.ByteBuffByteInput
-
- getAbsoluteOffsetInFile(int, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Get the absolute offset in given file with the relative global offset.
- getAbsolutePos(int) - Method in class org.apache.hadoop.hbase.util.ByteArrayHashKey
-
- getAcceptableFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getAccessChecker() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getAccessChecker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getAccessChecker() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getAccessChecker() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getAccessCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of accesses to the mob file cache.
- getAccessCounter() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- getAccessScope() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getAccessScope() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
Get this permission access scope.
- getACL() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns The serialized ACL for this operation, or null if none
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The serialized ACL for this operation, or null if none
- getAcl(String, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getAcl is an idempotent operation.
- getAclEntries(SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType, Set<String>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- getAcquireBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
acquire on each subprocedure.
- getAcquiredBarrier() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquiredBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAction() - Method in class org.apache.hadoop.hbase.client.Action
-
- getAction() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the action done if check succeeds
- getAction(int, int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
-
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
-
- getAction(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- getAction() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getActions() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getActive() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getActiveEnforcements() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Creates an object well-suited for the RegionServer to use in verifying active policies.
- getActiveExecutorCount() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getActiveFileName() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return the active file name that contains the real data.
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveGeneralRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active general handler.
- getActiveGeneralRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.logging.InternalLog4jUtils
-
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
-
- getActiveLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- getActiveMaster() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Get the address of active HMaster.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getActiveMaster(RpcController, RegistryProtos.GetActiveMasterRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getActiveMasterAddress() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the address of active master if there is one.
- getActiveMasterAddress() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getActiveMasterInfoPort() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- getActiveMasterInfoPort() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns info port of active master or 0 if any exception occurs.
- getActiveMasterServerName() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- getActiveMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveMetaPriorityRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active meta priority handler.
- getActiveMetaPriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- getActiveMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- getActivePoliciesAsMap() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActivePriorityRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active priority handler.
- getActivePriorityRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveProceduresNoCopy() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Should only be used when starting up, where the procedure workers have not been started.
- getActiveProcIds() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getActiveProcIds() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Returns all the active procedure ids in this bit set.
- getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveReadHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveReadRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveReadRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveReplicationRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active replication handler.
- getActiveReplicationRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- getActiveRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the total number of active handler.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveScanHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getActiveScanners() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getActiveScanners() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveScanRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveScanRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the hbase master active time
- getActiveTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getActiveUser() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
Returns the active user to which authorization checks should be applied.
- getActiveUser() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- getActiveUser() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
Returns the active user to which authorization checks should be applied.
- getActiveUser(ObserverContext<?>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Returns the active user to which authorization checks should be applied.
- getActiveUser(ObserverContext<?>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- getActiveUser() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveWriteHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveWriteRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active write rpc handler when use RWQueueRpcExecutor.
- getActiveWriteRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActivityTime() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- getAdaptiveTimeout(int, int) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
Get the adaptive timeout value when performing a retry
- getAddress() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getAddress() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- getAddress() - Method in class org.apache.hadoop.hbase.ServerName
-
- getAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Returns Address for this cluster instance.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncAdmin
implementation to administer an HBase cluster.
- getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Establishes a connection to the region server at the specified address.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getAdmin(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getAdmin() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- getAdmin(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
-
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
.
- getAdmin() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getAdmin() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getAdmin() - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
Obtain HBaseAdmin.
- getAdmin() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
Get a ThriftAdmin, ThriftAdmin is NOT thread safe
- getAdmin() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller doesn't close the admin afterwards.
- getAdminBuilder() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminBuilder(ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getAdminBuilder() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getAdminBuilder(ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getAdminForMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Get the admin service for master.
- getAdminForMaster() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getAdminStub(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getADummyTableName(String) - Static method in class org.apache.hadoop.hbase.TableName
-
It is used to create table names for old META, and ROOT table.
- getAgeAtEvictionSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getAgeInCacheSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the Age of Last Applied Op n
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getAgeOfLastShippedOp(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
get age of last shipped op of given wal group.
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get AgeOfLastShippedOp n
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getAggregateRequestPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Get the aggregate source to which this reports.
- getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Get the aggregate source to which this reports.
- getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- getAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getAlgorithm() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getAll(List<Get>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version for batch get.
- getAll() - Method in class org.apache.hadoop.hbase.master.MasterRegionServerList
-
- getAll() - Method in interface org.apache.hadoop.hbase.master.RegionServerList
-
Get all live region servers.
- getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all TableDescriptors.
- getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns a map from table name to table descriptor for all tables.
- getAllActiveProcIds() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Will be used when there are too many proc wal files.
- getAllCached() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getAllColumns(Table) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Returns a list of all the column families for a given Table.
- getAllExecutorStatuses() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllHFileRefs() - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getAllHFileRefs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Load all hfile references in all replication queues.
- getAllHFileRefs() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAllocationFailCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getAllocationFailWarningMessage(BucketAllocatorException, BucketCache.RAMQueueEntry) - Static method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Prepare and return a warning message for Bucket Allocator Exception
- getAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getAllocatorForTest() - Static method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns true when the constructor of this scan understands that the results they will see may
only represent a partial portion of a row.
- getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the set of peerIds of the clusters that have been connected and have an underlying
ReplicationPeer.
- getAllPeersFromHFileRefsQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getAllPeersFromHFileRefsQueue() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get list of all peers from hfile reference queue.
- getAllPeersFromHFileRefsQueue() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAllPeersFromHFileRefsQueue0() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAllQueues(ServerName) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getAllQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getAllQueues(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all queues for the specified region server.
- getAllQueues(ServerName) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAllQueues0(ServerName) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAllRegionLocations(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getAllRegions(Connection, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Lists all of the regions currently in META.
- getAllRegionServerByName() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- getAllRSGroupInfo(Connection) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- getAllScannersForTesting() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used in testing.
- getAllSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getAllSegments() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- getAllWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getAllWALs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Load all wals in all replication queues.
- getAllWALs() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getAndCheckRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Check passed name.
- getAndConvert(String, ZKConnectionRegistry.Converter<T>) - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getAndIncrAtomicInteger(AtomicInteger, int) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- getAndPrintRowContents(Table) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
Invokes Table#get and prints out the contents of the retrieved row.
- getAndPrintRowContents(Table) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
Invokes Table#get and prints out the contents of the retrieved row.
- getAndReset() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- getAndResetChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getAnnotatedPriority(RPCProtos.RequestHeader) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
See if the method has an annotation.
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Returns the map for holding unspecified (user) attributes
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Returns the map for holding unspecified (user) attributes
- getAppConfigurationEntry(String) - Method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient.KerberosConfiguration
-
- getAppConfigurationEntry(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication.JaasConfiguration
-
- getAppliedOps() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Gets the total number of OPs delivered to this sink.
- getArchiveDataDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getArchiveDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files in the archive
- getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files in the archive
- getArchiveExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
- getArchiveNsDir(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the path of the archived hfile.
- getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getArchivePath(Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getArchiveTableDir(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getArchiveZNode(Configuration, ZKWatcher) - Static method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
- getArchivingEnabled(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getArchivingEnabled(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getArgumentsFromCommandLine(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
- getAsFile - Variable in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- getAsInt(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads bytes at the given offset as an int value.
- getAsLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads bytes at the given offset as a long value.
- getAsShort(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Reads bytes at the given offset as a short value.
- getAssignedRegions() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getAssignedRegions() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getAssignMaxAttempts() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getAssignmentManagerMetrics() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getAssignmentMap() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Return the mapping between each region to its favored region server list.
- getAssignmentsForBalancer(TableStateManager, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
This is an EXPENSIVE clone.
- getAssignMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getAssignMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getAssignProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for assign procedure
- getAssignRetryImmediatelyMaxAttempts() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getAsyncConnection() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Return the shared
AsyncConnection
which is used for handling wal replication.
- getAsyncProcess() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getAsyncProcess() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns Default AsyncProcess associated with this connection.
- getAsyncProcess() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getAsyncProfilerHome() - Static method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getAttempt() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getAttemptingUser() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getAttemptingUser() - Method in class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
-
- getAttemptTimes() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the value in the webapp context.
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Return a table descriptor value as a string.
- getAttributeKeyLength() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getAttributeKeyOffset() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getAttributes() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- getAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getAuthHeader(HttpServletRequest) - Method in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet.HttpKerberosServerAction
-
Returns the base64 encoded auth header payload
- getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getAuthMethod() - Method in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
Returns the Hadoop UserGroupInformation.AuthenticationMethod
for this method.
- getAuthorizationID() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getAuthorizationID() - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The authorizations this Query is associated with.
- getAuthorizedUgi(String, SecretManager<TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider
-
- getAuthorizedUgi(String, SecretManager<TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- getAuthorizedUgi(String, SecretManager<TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslServerAuthenticationProvider
-
- getAuthorizedUgi(String, SecretManager<TokenIdentifier>) - Method in interface org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider
-
- getAuthorizedUgi(String, SecretManager<TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslServerAuthenticationProvider
-
- getAuthRenewalChore(UserGroupInformation, Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
- getAuths(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Deprecated.
- getAuths(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Get the authorization for a given user
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getAuthToken(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Get the authentication token of the user for the cluster specified in the configuration
- getAvailable() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Returns the path of the first available link.
- getAverageLatencyCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the average cluster load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Compute the average load across all region servers.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get Average Load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Returns the average load of the region servers in the cluster
- getAverageRegionSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the average region size to this region server.
- getAverageRegionSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getAverageRegionSizeMb(List<RegionInfo>, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Also make sure tableRegions contains regions of the same table
- getAverageRegionSizeMb() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
-
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Get average execution time of the measured method.
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.SimpleMovingAverage
-
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.WeightedMovingAverage
-
- getAverageTime() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
- getAvgKeyLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getAvgRegionSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the average region size for this table
- getAvgRegionSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Average age of store files hosted on this region server
- getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Average age of store files under this region
- getAvgStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getAvgStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Average age of store files for this table
- getAvgStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getAvgStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Average age of store files in this store
- getAvgValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- getBackgroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the underlying filesystem
- getBackoff(ServerName, byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns the configured client backoff policy
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
Returns the number of ms to wait on the client based on the
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
-
- getBackoffTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getBackoffTimeAndIncrementAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getBackReferenceFileName(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the referenced file name from the reference link directory path.
- getBackReferencesDir(Path, String) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the directory to store the link back references
- getBackupMasterAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the backup master addresses.
- getBackupMasterAddresses() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the backup master if it is available.
- getBackupMasterInfoPort(ZKWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get backup master info port.
- getBackupMasterNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of backup masters
- getBackupMasterNames() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getBackupMasterNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getBackupMasterNames() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a list of current backup masters.
- getBackupMasters() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
Returns list of registered backup masters.
- getBackupMasters() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getBackupMasters() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
- getBackupMastersAndRenewWatch(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Retrieves the list of registered backup masters and renews a watch on the znode for children
updates.
- getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getBalancedSplits(List<Pair<SnapshotProtos.SnapshotFileInfo, Long>>, int) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Given a list of file paths and sizes, create around ngroups in as balanced a way as possible.
- getBalancer(String, Configuration, List<BlockingQueue<CallRunner>>) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getBalancer() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getBalancerDecision() - Method in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
-
- getBalancerDecisions(int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getBalancerDecisions(int) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getBalancerDecisions(MasterProtos.BalancerDecisionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getBalancerDecisions() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- getBalancerDecisionsRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getBalancerRejection() - Method in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
-
- getBalancerRejections(int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getBalancerRejections(int) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getBalancerRejections(MasterProtos.BalancerRejectionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getBalancerRejections() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- getBalancerRejectionsRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- getBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getBarriers() - Method in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- getBaseConf() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
A split takes the config from the parent region & passes it to the daughter region's
constructor.
- getBaseMetrics() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- getBaseOffset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getBasePriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
Get the priority for a given request from the header and the param This doesn't consider which
user is sending the request at all.
- getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return for a single call to next()
- getBatch() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getBatch() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- getBatch() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getBatch() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns the number of cells to return in batch
- getBatchEntrySizeExcludeBulkLoad(WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
get batchEntry size excludes bulk load file sizes.
- getBatchHash() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- getBatchLimit() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getBatchPool() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getBatchProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getBatchSize() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- getBatchStartKey() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- getBatchWaitTimeMillis(int) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
Get the amount of time in milliseconds to wait till next check.
- getBestComparer() - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder
-
Deprecated.
- getBestComparer() - Static method in class org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder
-
Returns the Unsafe-using Comparer, or falls back to the pure-Java implementation if unable to
do so.
- getBestConverter() - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder
-
Deprecated.
- getBestConverter() - Static method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder
-
Returns the Unsafe-using Converter, or falls back to the pure-Java implementation if unable
to do so.
- getBestLocations(Configuration, HDFSBlocksDistribution, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
This computes the locations to be passed from the InputSplit.
- getBestLocations(Configuration, HDFSBlocksDistribution) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getBiggestMemStoreOfRegionReplica(SortedMap<Long, HRegion>, Set<HRegion>) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- getBiggestMemStoreRegion(SortedMap<Long, HRegion>, Set<HRegion>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- getBindAddress(Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getBitmapIndex(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Fetch block from cache.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Get the buffer of the block with the specified key.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache.
- getBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
May be null if this is a master which not carry table.
- getBlockCache() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The block cache instance.
- getBlockCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items in the block cache.
- getBlockCacheCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheDataBlockCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of DATA blocks in the block cache.
- getBlockCacheDataBlockCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items evicted from the block cache.
- getBlockCacheEvictedCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheFailedInsertions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of cache insertions that failed.
- getBlockCacheFailedInsertions() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the block cache that is free.
- getBlockCacheFreeSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve configured size for on heap block cache as percentage of total heap.
- getBlockCacheHitCachingPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of requests with the block cache turned on that hit the block cache.
- getBlockCacheHitCachingPercent() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to the block cache
- getBlockCacheHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of all requests that hit the block cache.
- getBlockCacheHitPercent() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to the block cache.
- getBlockCacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCachePrimaryEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items evicted from primary replica in the block cache.
- getBlockCachePrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCachePrimaryHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to primary replica in the block cache
- getBlockCachePrimaryHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCachePrimaryMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to primary replica in the block cache.
- getBlockCachePrimaryMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCaches() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns The list of sub blockcaches that make up this one; returns null if no sub caches.
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- getBlockCacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size (in bytes) of the block cache.
- getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of blocks currently cached in the block cache.
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
- getBlockDecodingContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- getBlockDistribution(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- getBlockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getBlockedRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of requests blocked because the memstore size is larger than blockingMemStoreSize
- getBlockedRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of blocked requests
- getBlockForCaching(CacheConfig) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Creates a new HFileBlock.
- getBlockingFileCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getBlockingFileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
The number of files required before flushes for this store will be blocked.
- getBlockingService() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- getBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the block locality index for a given host
- getBlockLocalityIndexForSsd(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the block locality index for a ssd for a given host
- getBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- getBlockPriority() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlockPriority() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getBlocksize() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The storefile/hfile blocksize for this column family.
- getBlocksize() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the cipher's internal block size
- getBlocksize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getBlocksLocalityWeightInternal(String, HDFSBlocksDistribution.Visitor) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getBlocksLocalWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the blocks local weight for a given host
- getBlocksLocalWeight() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getBlocksLocalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data at local weight of this region in the regionserver
- getBlocksLocalWeight() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getBlocksLocalWithSsdWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Get the blocks local weight with ssd for a given host
- getBlocksLocalWithSsdWeight() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getBlocksLocalWithSsdWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from blocksLocalWeight,this metric's numerator only include the data stored on ssd
- getBlocksLocalWithSsdWeight() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getBlocksTotalWeight() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the block total weight of this region
- getBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getBlockType() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns the block type after encoding
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the block type of this cached HFile block
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
The type of block this data should use.
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getBloomBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- getBloomBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the compound Bloom filter block size from the configuration
- getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getBloomChunkHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getBloomChunkHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getBloomChunkMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getBloomChunkMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBloomFilterEligibleRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getBloomFilterEligibleRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of requests which could have used bloom filters, but they weren't configured or loaded.
- getBloomFilterEligibleRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBloomFilterEligibleRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of requests which could have used bloom filters for this table, but they weren't
configured or loaded.
- getBloomFilterEligibleRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getBloomFilterEligibleRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of requests which could have used bloom filters, but they weren't configured or
loaded.
- getBloomFilterMetadata(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getBloomFilterMetrics() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getBloomFilterNegativeResultsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getBloomFilterNegativeResultsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of bloom filter requests which return a negative result.
- getBloomFilterNegativeResultsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBloomFilterNegativeResultsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of bloom filter requests which return a negative result for this table.
- getBloomFilterNegativeResultsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getBloomFilterNegativeResultsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of negative results for bloom filter requests for this store.
- getBloomFilterParam(BloomType, Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
- getBloomFilterRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getBloomFilterRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Count of bloom filter requests.
- getBloomFilterRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getBloomFilterRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns count of bloom filter requests for this table.
- getBloomFilterRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getBloomFilterRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns count of bloom filter results for this store.
- getBloomFilterSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getBloomFilterSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The total size of all Bloom filter blocks, not just loaded into the block cache
- getBloomFilterSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getBloomFilterType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns bloom filter type used for new StoreFiles in ColumnFamily
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response body
- getBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getBootstrapNodes(Configuration) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- getBootstrapNodes(Configuration) - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getBootstrapNodes(Configuration) - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- getBootstrapNodes() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- getBootstrapNodes(RpcController, RegistryProtos.GetBootstrapNodesRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionRequest
-
- getBoundariesPolicies() - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionRequest
-
- getBoundariesStoragePolicyForMajor(List<Long>, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- getBoundariesStoragePolicyForMinor(boolean, CompactionWindow, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- getBoundedCachedThreadPool(int, long, TimeUnit, ThreadFactory) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Create a new CachedThreadPool with a bounded number as the maximum thread size in the pool.
- getBrokenStoreFileCleaner() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getBucketCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- getBucketCacheStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getBucketIndex(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getBucketIndex(Object[], int) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getBuckets() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getBucketSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- getBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Returns the underlying array where the data gets accumulated
- getBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
-
To be used only in tests where the Cells are clearly assumed to be of type KeyValue and that we
need access to the backing array to do some test case related assertions.
- getBuffer() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Returns the buffer
- getBufferCount() - Method in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- getBufferCount(long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
- getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getBufferedMutator(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getBufferedMutator(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
n * the name of the table, as a string
- getBufferedMutator(TableName) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getBufferedMutator(BufferedMutatorParams) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getBufferedMutator(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getBufferedMutator(BufferedMutatorParams) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getBufferedMutatorBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getBufferedMutatorBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a read-only duplicate of the buffer this block stores internally ready to be read.
- getBuffers() - Method in class org.apache.hadoop.hbase.ipc.BufferChain
-
- getBufferSize() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getBufferSize(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- getBufferSize(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec.HadoopLz4Compressor
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- getBufferSize(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec.HadoopLzoCompressor
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- getBufferSize(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec.HadoopSnappyCompressor
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- getBufferSize(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec.HadoopZstdCompressor
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getBufferSize(long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
- getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a buffer that does not include the header and checksum.
- getBuilder() - Static method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getBuilder(WALCellCodec.ByteStringCompressor) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getBulkLoadDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
- getBulkLoadObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
-
- getBulkLoadObserver() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getBulkLoadTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the timestamp at which this bulk load file was generated.
- GetBulkTime() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetBulkTime
-
- getByNamespace(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all NamespaceDescriptors for a given namespace.
- getByNamespace(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Find descriptors by namespace.
- getBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory.QuotaGlobalsSettingsBypass
-
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the byte at the given offset from current position.
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getByteAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getByteBuffAllocator() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap.
- getByteBuffAllocator() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getByteBuffAllocatorHeapAllocationBytes() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getByteBuffAllocatorHeapAllocationBytes() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getByteBuffAllocatorHeapAllocRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getByteBuffAllocatorHeapAllocRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getByteBuffAllocatorPoolAllocationBytes() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getByteBuffAllocatorPoolAllocationBytes() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getByteBuffAllocatorTotalBufferCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getByteBuffAllocatorTotalBufferCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getByteBuffAllocatorUsedBufferCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getByteBuffAllocatorUsedBufferCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_! n
- getByteBuffers() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
We can be assured that the buffers returned by this method are all flipped
- getBytes() - Method in class org.apache.hadoop.hbase.ipc.BufferChain
-
Expensive.
- getBytes() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The underlying byte[].
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given buf
, from the position (inclusive) to
the limit (exclusive).
- getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Get the Writable's contents as a byte array
- getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Put a bunch of Writables as bytes all into the one byte array.
- getByteSize() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
- getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns Size of the bloom, in bytes
- getByteSize() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- getBytesPerChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getBytesPerChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Returns the configured bytesPerChecksum value.
- getBytesPerSec() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the read-rate from this stream, since creation.
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- getBytesRead() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a byte stream reading the data + checksum of this block
- getByteString(byte[]) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getByteStringCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getByteStringUncompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- getBytesWritten() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- getCache() - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
-
Get whether blocks should be cached for this Get.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether blocks should be cached for this Scan.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns true if HFile blocks should be cached on the servers for this scan, false otherwise
- getCacheCleanupChore(CatalogReplicaLoadBalanceSimpleSelector) - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- getCacheCompactedBlocksOnWriteThreshold() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns total file size in bytes threshold for caching while writing during compaction
- getCacheCompactedBlocksOnWriteThreshold(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- getCacheConf() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getCacheConf() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Used for tests.
- getCacheCount() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getCacheDataBlockPercent() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getCachedBlock(BlockCacheKey, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Retrieve block from cache.
- getCachedBlockStatsByFile() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getCachedFileNamesForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Used in testing.
- getCachedHeader(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Check atomic reference cache for this block's header.
- getCachedLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- getCachedLocation(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Search the cache for a location that fits our table and row key.
- getCachedLocation(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Search the cache for a location that fits our table and row key.
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- getCachedTime() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Returns Time we were cached at in nano seconds.
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getCacheLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- getCacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getCacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Returns true if inline blocks produced by this writer should be cached
- getCachePeriodMs() - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
For tests only, returns the configured cache period
- getCacheSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getCacheSize() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of cached mob files.
- getCacheSize() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- getCacheStats() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns caching the number of rows fetched when calling next on a scanner
- getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Get the number of rows that will be fetched on next
- getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- getCaching() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns the number of rows that the scanner to fetch at once
- getCallable() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getCallback() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getCallBack() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getCallDetails() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getCalledMethodNames(String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- getCaller() - Method in interface org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Returns the active user for the coprocessor call.
- getCaller() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- getCallMethod(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getCallMethodCount(String, String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- getCallMethodSize(String, String) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- getCallQueueCountsSummary() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Get call queue information
- getCallQueueInfo() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getCallQueueNames() - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- getCallQueueSizeSummary() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.FastPathRpcHandler
-
- getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler.FifoCallRunner
-
- getCallRunner() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- getCallsInProgress() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getCallTarget(Address, RegionInfo) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- getCallTimeMs() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- getCallTimeout() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
- getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- getCandidate() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets initial, full list of candidate store files to check for row-key-before.
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCandidateGenerators() - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- getCatalogFamily() - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column family used for meta columns.
- getCatalogFamily() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column family used for meta columns.
- getCatalogFamilyRow(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getCatalogJanitor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getCatalogJanitor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getCategory() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCause() - Method in exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
-
- getCause() - Method in exception org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler.TIOErrorWithCause
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCell() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- getCell() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Returns the Cell at the current position.
- getCell() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- getCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getCell() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns Instance of
Cell
.
- getCell() - Method in class org.apache.hadoop.hbase.mob.MobCell
-
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayMap
-
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkMap
-
- getCell(int) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- getCellBufSize() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- getCellBuilder() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns a CellBuilder so that coprocessors can build cells.
- getCellBuilder() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getCellCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrContext
-
- getCellComparator(TableName) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getCellComparator(byte[]) - Static method in class org.apache.hadoop.hbase.CellComparatorImpl
-
Utility method that makes a guess at comparator to use based off passed tableName.
- getCellComparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCellComparator() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Return the comparator passed to this delete tracker
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- getCellComparator() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
- getCellComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
The comparator to be used with the region
- getCellCount() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return the key portion of the passed cell
as a String.
- getCellKeyAsString(Cell, Function<Cell, String>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return the Key portion of the passed cell
as a String.
- getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
This method exists just to encapsulate how we serialize keys.
- getCellLength(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.Segment
-
Get cell length after serialized in
KeyValue
- getCellList(byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Creates an empty list if one doesn't exist for the given column family or else it returns the
associated list of Cell objects.
- getCellPermissionsForUser(User, Cell) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- getCells() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
Returns the cells
- getCells() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- getCellScanner() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The CellScanner that can carry input and result payload.
- getCellScanner() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns number of cells in segment
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- getCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns Number of Cells in this snapshot.
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- getCellsCountCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getCellsCountCompactedFromMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of cells moved from mob during compaction.
- getCellsCountCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCellsCountCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getCellsCountCompactedToMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of cells moved to mob during compaction.
- getCellsCountCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCellSet() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns a set of all cells in the segment
- getCellSet() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns a set of all cells in the segment
- getCellsPerTimeoutCheck(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getCellsPerTimeoutCheck() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getCellsSizeCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getCellsSizeCompactedFromMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of cells moved from mob during compaction, in bytes.
- getCellsSizeCompactedFromMob() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCellsSizeCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getCellsSizeCompactedToMob() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of cells moved to mob during compaction, in bytes.
- getCellsSizeCompactedToMob() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getCellTTLColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getCellTTLColumnLength() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getCellTTLColumnOffset() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type n * @return the cell-type
instance from the PB message
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns CellVisibility associated with cells in this Mutation.
- getCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getCellVisibilityColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getCellVisibilityColumnLength() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getCellVisibilityColumnOffset() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Returns The chance that a row gets included.
- getChannelAllocator(Configuration) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- getChar() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- getCharacter() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- getCharset() - Method in interface org.apache.hadoop.hbase.filter.RegexStringComparator.Engine
-
Returns the name of the configured charset
- getCharset() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- getCharset() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that failed.
- getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of failed checkAndMutate guards
- getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that passed.
- getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of checkAndMutate guards that passed
- getCheckingEndTimestamp() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
Used for web ui to show when the HBCK checking report generated.
- getCheckingStartTimestamp() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
Used for web ui to show when the HBCK checking started.
- getChecksumFailures() - Method in interface org.apache.hadoop.hbase.io.MetricsIOWrapper
-
- getChecksumFailures() - Method in class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
-
- getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getChecksumType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getChecksumType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Returns the configured checksum algorithm.
- getChildAclOperations() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- getChildDataAndWatchForNewChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getChildDataAndWatchForNewChildren(ZKWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getChildExps() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getChildren() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
- getChildren() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- getChildren() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileableStoreFile
-
- getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildrenLatch() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getChore() - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- getChorePoolSize() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- getChoreService() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
If choreService has not been created yet, create the ChoreService.
- getChoreService() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
If choreService has not been created yet, create the ChoreService.
- getChoreService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getChoreService() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getChoreService() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getChoreService() - Method in interface org.apache.hadoop.hbase.Server
-
- getChunk() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Creates and inits a data chunk.
- getChunk(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Creates and inits a chunk with specific type.
- getChunk(ChunkCreator.ChunkType, int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Creates and inits a chunk.
- getChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getChunk() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
Poll a chunk from the pool, reset it if not null, else create a new chunk to return if we
have not yet created max allowed chunks count.
- getChunkId() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Extracts the id of the backing bytebuffer of this cell if it was obtained from fixed sized
chunks as in case of MemstoreLAB
- getChunkId() - Method in class org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
-
- getChunkId() - Method in class org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
-
- getChunkSize() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getChunkSize(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getChunkSize() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- getChunkToWrite() - Method in class org.apache.hadoop.hbase.wal.BoundedEntryBuffers
-
- getChunkToWrite() - Method in class org.apache.hadoop.hbase.wal.EntryBuffers
-
Returns RegionEntryBuffer a buffer of edits to be written.
- getChunkType() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Get an Cipher
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get an cipher given a name
- getCipherOption(DataTransferProtos.DataTransferEncryptorMessageProto, boolean, SaslClient) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- getCipherOptions() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getClass(String, Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClass(String, Class<? extends U>, Class<U>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- getClassByName(String) - Method in interface org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfigMap
-
- getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- getClassByName(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClassByNameOrNull(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClasses(String, Class<?>...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the classloader for the loaded coprocessor instance
- getClassLoader(Path, ClassLoader, String, Configuration) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Get a CoprocessorClassLoader for a coprocessor jar path from cache.
- getClassLoader() - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- getClassLoaderForClass(Class<?>) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getClassLoaderForCodec() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
Returns the classloader to load the Codec class from.
- getClassName() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns the name of the class or interface represented by this object.
- getClassName() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- getClassName() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- getClassName() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- getClassName() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- getCleanerThreadCheckIntervalMsec() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getCleanerThreads() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getCleanerThreadTimeoutMsec() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getCleanerThreadTimeoutMsec() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Establishes a connection to the region server at the specified address, and returns a region
client protocol.
- getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
-
- getClient() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getClient() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
If an RPC call is currently running, produces a String representation of the connection from
which it was received.
- getClient() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- getClient() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftClientBuilder
-
- getClient() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.DefaultThriftClientBuilder
-
- getClient() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.HTTPThriftClientBuilder
-
- getClientAckTime() - Method in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getClientAddress() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getClientAddress() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- getClientIdAuditPrefix() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns Client info for use as prefix on an audit log string; who did an action
- getClientIdAuditPrefix() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
Metrics collected at client level for a user(needed for reporting through clusterStatus and
hbtop currently)
- getClientMetrics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- getClientMetrics() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns metrics per client(hostname)
- getClientMetrics() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
-
- getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Get the list of client ports.
- getClientVersionInfo() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the client version info, or null if the information is not present
- getClientVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getClientZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the client ZK Quorum servers string
- getClosedRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- getCloseMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getCloseMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getCloseProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for CloseRegionProcedure
- getClosestRegionInfo(Connection, TableName, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns Get closest metatable region row to passed row
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the cluster definition
- getClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getClusterConnection() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getClusterConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' cluster connection.
- getClusterId() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- getClusterId() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns the cluster ID unique to this HBase cluster.
- getClusterId() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Should only be called once.
- getClusterId() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- getClusterId(byte[]) - Static method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getClusterId() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getClusterId() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
Returns a cached copy of the cluster ID.
- getClusterId() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns The unique identifier generated for this cluster
- getClusterId() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getClusterId(RpcController, RegistryProtos.GetClusterIdRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getClusterId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getClusterId(Token<AuthenticationTokenIdentifier>) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
- getClusterId() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getClusterId() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getClusterId() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getClusterId() - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getClusterId() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Returns Cluster ID for the HBase cluster or null if there is an err making the connection.
- getClusterId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the value of the unique cluster ID stored for this HBase instance.
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns the set of clusterIds that have consumed the mutation
- getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- getClusterIds() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
Returns The cluster ids that have the change.
- getClusterIds() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns the set of cluster Ids that have consumed the change
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get whole cluster metrics, containing status about:
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getClusterMetrics() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns cluster status
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterMetrics() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getClusterMetricsWithoutCoprocessor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterMetricsWithoutCoprocessor(EnumSet<ClusterMetrics.Option>) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterSchema() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterSchema() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getClusterState() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getClusterVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch to StorageClusterVersionResource
- getCode() - Method in enum org.apache.hadoop.hbase.Cell.Type
-
- getCode() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- getCode() - Method in enum org.apache.hadoop.hbase.KeyValue.Type
-
- getCode() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response code
- getCode() - Method in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
Returns the unique value to identify this authentication method among other HBase auth methods.
- getCode() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
- getCodec(Configuration) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getCodec() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Encapsulate the ugly casting and RuntimeException conversion in private method.
- getCodec(Configuration, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- getCodec(Configuration, String, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getCodec(Configuration, Encryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodec(Configuration, Decryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getColdWindowStoragePolicy() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getColFamilyCutoffTime(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
-
- getColorValue(Color, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- getColumn() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
-
- getColumn() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
Returns the column
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnCount() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnFamilies(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- getColumnFamily(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the ColumnDescriptor for a specific column family with name as specified by the
parameter column.
- getColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the ColumnFamilyDescriptor for a specific column family with name as specified by the
parameter column.
- getColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getColumnFamily() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getColumnFamily(int) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Retrieve the column family at the given index from the table descriptor
- getColumnFamily() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getColumnFamilyCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the count of the column families of the table.
- getColumnFamilyCount() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getColumnFamilyCount() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the count of the column families of the table.
- getColumnFamilyDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getColumnFamilyDescriptor() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getColumnFamilyList(Set<String>, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
To get the column family list according to the column family dirs nn * @return a set of column
families n
- getColumnFamilyMap() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
-
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getColumnFamilyNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getColumnFamilyNames() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyNames() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns all the column family names of the current table.
- getColumnFamilyNames() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getColumnFamilyTimeRange() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns A map of column families to time ranges
- getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn()
returns SKIP.
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Used by matcher and scan/get to get a hint of the next column to seek to after checkColumn()
returns SKIP.
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLength(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getColumnOffset(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getColumns() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
-
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns list of columns of interest in column:qualifier format, or empty for all
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Returns the columns
- getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getColumnsAdded() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getColumnsDeleted() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getColumnsModified() - Method in class org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
-
- getCommittedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- getCommittedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Returns the newly committed files from the flush.
- getCommmand() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getCommonOptions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- getCompactBoundariesForMajor(Collection<HStoreFile>, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
Return a list of boundaries for multiple compaction output in ascending order.
- getCompactedCellCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompactedCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of already compacted kvs in current compaction
- getCompactedCellCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during minor compactions.
- getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells processed during minor compactions
- getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during minor compactions, in bytes.
- getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total amount of data processed during minor compactions, in bytes
- getCompactedfiles() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompactedfiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
List of compacted files inside this store that needs to be excluded in reads because further
new reads will be using only the newly created files out of compaction.
- getCompactedfiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCompactedFilesCount() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getCompactedFilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedFilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Count of compacted store files
- getCompactedFilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns the number of compacted files.
- getCompactedFilesCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCompactedFilesSupplier() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getCompactedHFilesDischarger() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactedStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getCompactingCellCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompactingCellCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total number of cells in current compaction
- getCompactingCellCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getCompaction(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
- getCompactionBoundariesForMinor(CompactionWindow, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
Returns a list of boundaries for multiple compaction output from minTimestamp to maxTimestamp.
- getCompactionCheckMultiplier() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactionCheckMultiplier() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getCompactionPolicy() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Compaction policy to use.
- getCompactionPolicyForDateTieredWindow() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
This value can represent the degree of emergency of compaction for this store.
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCompactionProgress() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
getter for CompactionProgress object
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the current size of the queue containing regions that are processed.
- getCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the compaction queue
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCompactionRatio() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns Ratio used for compaction
- getCompactionRatioOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns Off peak Ratio used for compaction
- getCompactionRequestor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionRequestor() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getCompactionRequestsLeftToFinish() - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCompactionState(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table.
- getCompactionState(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get the compaction state of the table
- getCompactionState() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompactionState() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the compaction state of this region
- getCompactionState() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCompactionState() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns if a given region is in compaction now.
- getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getCompactionState(TableName, CompactType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getCompactionThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getCompactor() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Compactor to use.
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns The priority that this region should have in the compaction queue
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactPriority() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompactSplitThread() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getComparator(Comparator<ColumnFamilyDescriptor>) - Static method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the comparator
- getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns comparator
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
n
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns the Cell comparator used by this segment
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the comparator for comparing two cells.
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getComparatorClass(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getCompareOp() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the comparison operator
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
n
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getCompareOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
Returns the data to be used to compare this
to another object.
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.ReversedRowRange
-
- getComparisonData() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getCompletedRecoveredEditsFilePath(Path, long) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Get the completed recovered edits file path, renaming it to be by last edit in the file from
its first edit.
- getCompletedSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getCompletedSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompletedSequenceId() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getCompletedSize() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getCompletedSnapshotDir(SnapshotProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a specified snapshot.
- getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a completed snapshot.
- getCompletedSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCompletedSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
List the currently available/stored snapshots.
- getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Gets the list of all completed snapshots.
- getCompletedSnapshots(Path, boolean) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Gets the list of all completed snapshots.
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCompleteTracker(CompactionLifeCycleTracker, IntSupplier) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getCompletionTime() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task completion time.
- getCompletionTime() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Returns -1 if the snapshot is in progress, otherwise the completion timestamp.
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getComponents() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- getComponents() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator
-
- getCompressedSize(Compression.Algorithm, Compressor, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of compressed data assuming that buffer will be compressed using given algorithm.
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompression() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting.
- getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getCompressor(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Encapsulate the ugly casting and RuntimeException conversion in private method.
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getCompressorType() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getComputedSteps() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getComputedTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getConcurrentCallsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- getConf() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getConf() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- getConf() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getConf() - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- getConf() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- getConf() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
Returns The current compaction configuration settings.
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getConf(Configuration, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.DefaultSourceFSConfigurationProvider
-
- getConf(Configuration, String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.SourceFSConfigurationProvider
-
Returns the source cluster file system configuration for the given source cluster replication
ID.
- getConf() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- getConf() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getConf() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get configuration of this cluster.
- getConf() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getConf() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- getConf() - Method in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- getConfFromContext() - Method in class org.apache.hadoop.hbase.http.conf.ConfServlet
-
Return the Configuration of the daemon hosting this servlet.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Configuration used by the instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns an unmodifiable map.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns Configuration instance being used by this Connection instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Getter for fetching an unmodifiable map.
- getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns the Configuration used by this LocalHBaseCluster
- getConfiguration() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets current config.
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get the configuration object required to communicate with this peer
- getConfiguration(String, FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
Returns the configuration to be used by the authentication filter to initialize the
authentication handler.
- getConfiguration() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfiguration() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- getConfigurationManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getConfigurationManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns : Returns the ConfigurationManager object for testing purposes.
- getConfigurationValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Getter for accessing the configuration value by key
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConfiguredHashAlgorithm(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns the Hash Algorithm defined in the crypto configuration.
- getConfiguredInputFormat(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- getConfiguredScanForJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- getConfResourceAsInputStream(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getConfResourceAsReader(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getConn() - Method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- getConnectedZooKeeper(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
-
Get a ZooKeeper instance and wait until it connected before returning.
- getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns Connection used by this object.
- getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Returns Connection used by this object.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
-
INTERNAL Used by unit tests and tools to do low-level manipulations.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- getConnection() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
Returns
Connection
instance used by this Callable.
- getConnection() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns the hosts' Connection to the Cluster.
- getConnection(ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Get a connection from the pool, or create a new one and add it to the pool.
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Subclasses of HBaseServer can override this to provide their own Connection implementations.
- getConnection() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerCall
-
Deprecated.
- getConnection() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- getConnection() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- getConnection() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- getConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConnection() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getConnection() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- getConnection() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Return the shared
Connection
which is used for handling bulk load hfiles replication.
- getConnection() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' connection.
- getConnection() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getConnectionCache() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Returns the ConnectionCache instance
- getConnectionConfiguration() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns a ConnectionConfiguration object holding parsed configuration values
- getConnectionConfiguration() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getConnectionExceptionTypes() - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
For test only.
- getConnectionHeader() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- getConnectionHeaderPreamble() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- getConnectionMetrics() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getConnectionMetrics() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns the MetricsConnection instance associated with this connection.
- getConnectionMetrics() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getConnectionRegistry() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getConnectionRegistry() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getConnectionRegistry() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getConnectionString() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Return the connection string associated with this registry instance.
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getConnectionString(Configuration) - Static method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- getConnectionString() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getConnectorAddress(int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the address that corresponds to a particular connector.
- getConnectString() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- getConnectTimeout() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getConsistency() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getConstraints(TableDescriptor, ClassLoader) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Get the constraints stored in the table descriptor n * To read from n * To use when loading
classes.
- getContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteArrayBackedNode
-
- getContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteBufferBackedNode
-
- getContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.Node
-
- getContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- getContext(Class<?>) - Method in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
-
- getControllerException(RpcController) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Retreivies exception stored during RPC invocation.
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getCoordinatedStateManager() - Method in interface org.apache.hadoop.hbase.Server
-
Get CoordinatedStateManager instance for this server.
- getCoordinator() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Returns distributed commit coordinator for all running snapshots
- getCoprocessorDescriptors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Return the list of attached co-processor represented
- getCoprocessorDescriptors() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Return the list of attached co-processor represented by their name className
- getCoprocessorDescriptors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the coprocessor host
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Returns Coprocessor host.
- getCoprocessorNames() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Return the RegionServer-level and Region-level coprocessors
- getCoprocessorNames() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getCoprocessors() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Used to create a parameter to the HServerLoad constructor so that HServerLoad can provide
information about the coprocessors loaded by this regionserver.
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getCoprocessorServiceCall(Descriptors.MethodDescriptor, Message, byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getCoprocessorServiceRequest(Descriptors.MethodDescriptor, Message, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getCopyOfOnlineRegionsSortedByOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCopyOfOnlineRegionsSortedByOnHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns number of threads in the core pool of the underlying ScheduledThreadPoolExecutor
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Returns the core pool size settings.
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCorePoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of corrupted file paths after checkTables is called.
- getCorruptedLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getCorruptedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of corrupted mob file paths after checkTables is called.
- getCorruptedProcs() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- getCorruptedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of corrupted store files
- getCostFromRl(BalancerRegionLoad) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- getCostFromRl(BalancerRegionLoad) - Method in class org.apache.hadoop.hbase.master.balancer.MemStoreSizeCostFunction
-
- getCostFromRl(BalancerRegionLoad) - Method in class org.apache.hadoop.hbase.master.balancer.ReadRequestCostFunction
-
- getCostFromRl(BalancerRegionLoad) - Method in class org.apache.hadoop.hbase.master.balancer.StoreFileCostFunction
-
- getCostFromRl(BalancerRegionLoad) - Method in class org.apache.hadoop.hbase.master.balancer.WriteRequestCostFunction
-
- getCostFuncInfoList() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
-
- getCostFunctionNames() - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
Get the names of the cost functions
- getCouldNotCommunicateWithServer() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- getCount() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker.ServerErrors
-
- getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns count of blocks in the cache
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Returns the current value.
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Return the total number of values added to the histogram.
- getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
-
- getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getCount() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the number of events.
- getCount() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the number of values in the snapshot.
- getCount() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- getCount() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
- getCount() - Method in interface org.apache.hadoop.metrics2.MetricHistogram
-
Return the total number of values added to the histogram.
- getCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Returns the number of items that the estimator has processed
- getCountAtOrBelow(long) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the total count below the given value
- getCountData() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- getCounter(String) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
n * @return
AtomicLong
instance for this counter name, null if counter does not exist.
- getCounter(Enum<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- getCounter(String, String) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- getCounter(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a MetricMutableCounterLong from the storage.
- getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCountOfCommonTableRegions() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
Returns Count of regions on this server that share the table this.region belongs to
- getCpRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getCpRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getCreatedTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns timestamp when this file was created (as returned by filesystem)
- getCreateFlags(boolean) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- getCreateTime() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getCumulativeNumKV(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- getCurBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurBlockCacheUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurCellSerializedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getCurMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurMemStoreUsed() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the User
instance within current execution context.
- getCurrent() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Return the current user within the current execution context
- getCurrentBandwidth() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getCurrentBatchPool() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getCurrentBloomSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Needed for features such as delayed calls.
- getCurrentChunk() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getCurrentClientVersionInfo() - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Returns the versionInfo extracted from the current RpcCallContext
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCurrentCompactedKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Returns the completed count of key values in currently running compaction
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns The number of current compacted key-values
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getCurrentConnection() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Get the cached connection for the current user.
- getCurrentDataSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of data blocks, in bytes.
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getCurrentDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getCurrentEligibleFiles(ArrayList<HStoreFile>, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- getCurrentFileName() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This is a convenience method that computes a new filename with a given using the current WAL
file-number n
- getCurrentFileName(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
return the current filename from the current wal.
- getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the filesystem of the hbase rootdir.
- getCurrentForTesting() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getCurrentHash() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
Get the current hash
- getCurrentHour() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- getCurrentIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
Get the current key
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALKeyRecordReader
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- getCurrentMetaLookupPool() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getCurrentMode() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getCurrentParallelPutCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCurrentParallelPutCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getCurrentPath() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the current log that's replicated
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
Returns the Path
of the current WAL
- getCurrentPathStat() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- getCurrentPayloadCarryingRpcController() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getCurrentPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- getCurrentPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- getCurrentPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getCurrentRunTime() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
-
Returns the time since the current procedure is running
- getCurrentSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of the block cache, in bytes.
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getCurrentSnapshotFromQuotaTable(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns the current space quota snapshot of the given tableName
from
QuotaTableUtil.QUOTA_TABLE_NAME
or null if the no quota information is available for
that tableName.
- getCurrentSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given namespace
or null if the Master has
no quota information on that namespace.
- getCurrentSpaceQuotaSnapshot(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the Master's view of a quota on the given tableName
or null if the Master has
no quota information on that table.
- getCurrentSpaceQuotaSnapshot(String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(RawAsyncHBaseAdmin.Converter<SpaceQuotaSnapshot, QuotaProtos.GetQuotaStatesResponse>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getCurrentSpaceQuotaSnapshot(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getCurrentSpaceQuotaSnapshot(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getCurrentState() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getCurrentState() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- getCurrentState(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- getCurrentState(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
- getCurrentState(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- getCurrentStateId() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
This method is used from test code as it cannot be assumed that state transition will happen
sequentially.
- getCurrentTerm() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- getCurrentTime() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getCurrentUserName() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Returns the userName for the current logged-in user.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- getCurrentWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the cursor if this Result is a cursor result.
- getCursor() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getCursor() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- getCursorPosition() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- getCursorPosition() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- getCurTaskZKVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getCycles() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- getData() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- getData() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
Returns This chunk's backing data.
- getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Gets the data of the node.
- getData(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get znode data.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- getDataAndWatch(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- getDataAndWatch(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZKWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZKWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- GetDataAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
-
- GetDataAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.GetDataAsyncCallback
-
- getDataBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of data blocks currently cached in the block cache.
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getDataBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the data block encoder
- getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and create data block encoder for given id;
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the data block encoding algorithm used in block cache and optionally on disk
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Returns the data block encoding
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns get data block encoding id that was used to encode this block
- getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getDataChecksumType() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Function to get corresponding DataChecksum.Type
.
- getDataChunksPool() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getDataCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getDataDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getDataFileName(int) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getDataHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getDataHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getDataHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getDataInMemoryWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Ammount of data in the memstore but not in the WAL because mutations explicitly had their WAL
turned off.
- getDataInMemoryWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the size of data processed bypassing the WAL, in bytes
- getDataInternal(ZKWatcher, String, Stat, boolean, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getDataLength() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor.PacketAckData
-
- getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
Returns the data locality of region in the regionserver.
- getDataLocality() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the data locality of region in the regionserver.
- getDataLocality() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getDataLocalityForSsd() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getDataLocalityForSsd() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Different from dataLocality,this metric's numerator only include the data stored on ssd
- getDataLocalityForSsd() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getDataMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getDataMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getDataMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getDataNodeHosts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getDatanodeInfoMap() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- getDataNodePort() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getDataNoWatch(ZKWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode without setting a watch.
- getDataNsDir(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getDataRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the rootDir.
- getDataSetWatch(String, Long) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDataSetWatchAsync() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getDataSetWatchFailure(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDataSetWatchFailure(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getDataSetWatchSuccess(String, byte[], int) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDataSetWatchSuccess(String, byte[]) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns Size of data.
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns Sum of all cell sizes.
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- getDataSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getDataSize() - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- getDataSize() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- getDataSizeLimit() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getDataSizeProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getDataTableDir(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getDataToWriteToZooKeeper(Map<String, Integer>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the labels data to be written to zookeeper.
- getDataWriter() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter data (the actual Bloom bits).
- getDate() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the date string.
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDateFromName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
get date from MobFileName.
- getDateTieredCompactionWindowFactory() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getDateTieredIncomingWindowMin() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getDateTieredMaxStoreFileAgeMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getDaughterOneRI() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getDaughterRegionIdTimestamp(RegionInfo) - Static method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Calculate daughter regionid to use.
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the daughter regions by reading the corresponding columns of the catalog table Result.
- getDaughterTwoRI() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getDeadline(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the deadline of the specified request.
- getDeadline() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Return the deadline of this call.
- getDeadline() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
Based on the request content, returns the deadline of the request.
- getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getDeadNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getDeadNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Returns the list of dead nodes
- getDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the dead region servers
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getDeadServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the dead list
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
Returns the names of region servers on the dead list
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getDeadServers(long) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Get the servers which died since a given timestamp.
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDeadServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.CellCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- getDecoder(InputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getDecoder(ByteBuff) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getDecoder(ByteBuff) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getDecompressorType() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDeepCopy() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
-
- getDeepCopy() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode
-
- getDefaultBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Get the default decoder for blocks from this file.
- getDefaultBlockDecodingContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return the number of bytes that large input files should be optimally be split into to minimize
i/o time.
- getDefaultBufferSize(FileSystem) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the default buffer size to use during writes.
- getDefaultChecksumType() - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
- getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getDefaultEventLoopConfig(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
- getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getDefaultExtension() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getDefaultHost(String, String) - Static method in class org.apache.hadoop.hbase.util.DNS
-
Wrapper around DNS.getDefaultHost(String, String), calling DNS.getDefaultHost(String, String,
boolean) when available.
- getDefaultLength() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
-
- getDefaultLoadBalancerClass() - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
- getDefaultParameters(Configuration) - Static method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
-
- getDefaultParameters(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
-
- getDefaultProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getDefaultRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- getDefaultServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getDefaultServers(List<RSGroupInfo>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getDefaultSlop() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- getDefaultSortField() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- getDefaultSortField() - Method in interface org.apache.hadoop.hbase.hbtop.mode.ModeStrategy
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
-
- getDefaultSortField() - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
-
- getDefaultThreadPool(Configuration) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
Returns a Thread pool for the RPC's to region replicas.
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDefaultValuesBytes() - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getDefaultWorkingSnapshotDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the default working directory for snapshots - where they are built, where they are
temporarily copied on export, etc.
- getDefinedImplemantations() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
-
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedObject
-
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager.Lease
-
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- getDelay(TimeUnit) - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.Task
-
- getDelegate() - Method in class org.apache.hadoop.hbase.io.DelegatingInputStream
-
- getDelegate() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getDelegate() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Retrieves the singleton instance of the
EnvironmentEdge
that is being managed.
- getDelegatee() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
-
Deprecated.
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
Deprecated.
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDelegateeForModification() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getDelegatesForTesting() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Exposed for TESTING!
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
- getDeletableFiles(Iterable<FileStatus>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Determines which of the given files are safe to delete
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- getDeleteBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves delete family Bloom filter metadata as appropriate for each
HFile
version.
- getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getDeleteFamilyBloomHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getDeleteFamilyBloomHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getDeleteFamilyBloomMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getDeleteFamilyBloomMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from start of buffer forwards.
- getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from end of buffer backwards.
- getDeployedOn() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDescription() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
Returns a description of the operation
- getDescription() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.NamespaceProcedureBiConsumer
-
- getDescription() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ReplicationProcedureBiConsumer
-
- getDescription() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.TableProcedureBiConsumer
-
- getDescription() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- getDescription() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- getDescription() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
-
- getDescription() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- getDescription() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- getDescription() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getDescription() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getDescription() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task's description.
- getDescription() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- getDescription() - Method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the descriptive name as
RegionState
does it but with hidden startkey optionally
- getDescriptiveNameFromRegionStateForDisplay(RegionState, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a table descriptor.
- getDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Method for getting the tableDescriptor
- getDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getDescriptor() - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getDescriptor() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getDescriptor(TableName) - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- getDescriptor(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getDescriptor() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
- getDeserializer(int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Get the cacheable deserializer registered at the given identifier Id.
- getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDeserializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
Deprecated.
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getDeserializerIdentifier() - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Get the identifier of this deserializer.
- getDeserializerIdentifier() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockDeserializer
-
- getDesiredMaxFileSize() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- getDestination() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the destination server for the plan for this region.
- getDestinationServer() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionCloseOperation
-
- getDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Returns the configuration that was provided previously
- getDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDeterministicRandomSeed(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Creates a deterministic hash code for store file collection.
- getDeviation() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Returns deviation of the data values that are in the current list of data values
- getDFSHedgedReadMetrics(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
n * @return The DFSClient DFSHedgedReadMetrics instance or null if can't be found or not on
hdfs.
- getDFSReplication() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns replication factor set for this CF
- getDFSReplication() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getDFSReplication() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDictionary(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.compress.DictionaryCache
-
Load a dictionary or return a previously cached load.
- getDictionary(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getDictionary(Enum) - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- getDictionaryId(byte[]) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getDifferentFavoredNode(BalancerClusterState, List<ServerName>, int) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLocalityPicker
-
- getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
Returns the current amount of direct memory used.
- getDirUri(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the URI in the string format
- getDisabledTableRegions() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- getDispersionInformation() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return a list which contains 3 elements: average dispersion score, max dispersion score and min
dispersion score as first, second and third elements, respectively.
- getDisplayedHeaders() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- getDisplayedRecords() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- getDoasFromHeader(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
The purpose of this function is to get the doAs parameter of a http request case insensitively
n * @return doAs parameter if exists or null otherwise
- getDouble(String, double) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getDrainingRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the draining region servers
- getDrainingRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns A copy of the internal list of draining servers.
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDstTrackerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- getDummyHeaderForVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return the appropriate DUMMY_HEADER for the minor version
- getDummyHeaderForVersion(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return the appropriate DUMMY_HEADER for the minor version
- getDumpServlet() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getDumpServlet() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the durability setting for the table.
- getDurability() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the durability setting for the table.
- getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the durability setting for the table.
- getEarliestFlushTimeForAllStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getEarliestFlushTimeForAllStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getEarliestMemStoreSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getEarliestMemStoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getEarliestMemStoreSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- getEarliestMemStoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- getEarliestMemStoreSeqNum(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- getEarliestMemStoreSeqNum(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Gets the earliest unflushed sequence id in the memstore for the store.
- getEdit() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the edit n
- getEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getEditsFiltered() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Gets the number of edits not eligible for replication this source queue logs so far.
- getEditsRead() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getEffectiveDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getEffectiveDurability(Durability) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns effective durability from the passed durability and the table descriptor.
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEffectiveLevel(String) - Static method in class org.apache.hadoop.hbase.logging.InternalLog4jUtils
-
- getEffectiveLevel(String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
-
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Get the current thread local effective user
- getElements() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- getEligibleRequestsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for requests which could have used bloom filters but wasn't defined or
loaded.
- getEmptyRegionInfo() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getEnabled() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- getEnabled() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- getEnabled() - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- getEncodedBuffer(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getEncodedCompressedSize(Compression.Algorithm, Compressor) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Estimate size after second stage of compression (e.g.
- getEncodedData() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Returns encoded data with header
- getEncodedDataSizeWritten() - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
-
- getEncodedName() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns the encoded region name
- getEncodedName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name.
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the encoded region name
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- getEncodedNameAsBytes() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the encoded region name as an array of bytes.
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getEncodedNodeName(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
Gets the full path node name for the log file being split.
- getEncodedPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getEncodedPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Encoded Path if this StoreFile was made with a Stream.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's encoded name.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns encoded region name
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns encoded region name
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- getEncoder(OutputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
-
- getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getEncodingState() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getEncodingState() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns the encoding state
- getEncodingState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- getEncryptionContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getEncryptionContext() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the raw crypto key attribute for the family, or null if not set
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEncryptionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Return the encryption algorithm in use by this family
- getEncryptionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Get an encryptor for encrypting data.
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEnd() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Inclusive.
- getEndKey() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry
-
- getEndKey() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns the endKey
- getEndKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the endKey.
- getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the endKey
- getEndKey(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getEndKey() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Returns the end key
- getEndKey() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getEndKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the end key for display.
- getEndKeyForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndpointObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
-
- getEndpointObserver() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns end row key
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEndRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the end row for a given stripe.
- getEndRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns end row
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEndTime() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns the upper bound on timestamps of items of interest
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEngine() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns number of KV entries in this HFile
- getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getEntries() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getEntries() - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- getEntriesTimeout - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- getEntry() - Method in class org.apache.hadoop.hbase.client.SingleResponse
-
- getEntry(short) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Gets an entry from the dictionary.
- getEntry(short) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- getEntryBySubEntry(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Finds the entry corresponding to the deeper-level index block containing the given
deeper-level entry (a "sub-entry"), assuming a global 0-based ordering of sub-entries.
- getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEntrySizeExcludeBulkLoad(WAL.Entry) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- getEntrySizeIncludeBulkLoad(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- getEntryUsers(Table, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- getEnum(String, T) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getEnvironment() - Method in interface org.apache.hadoop.hbase.coprocessor.ObserverContext
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getErr() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- getErrorCheckable() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
exposed for testing.
- getErrorHandler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getErrorHandler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getErrorList() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- getErrorList() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- getErrorMessages() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getErrorMonitor() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Get the ForeignExceptionDispatcher
- getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the Bloom filter error rate in the given configuration
- getErrorReporter(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getErrorResponse(String, Exception) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getErrors() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getErrors() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getEstimatedEntrySize(WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- getEstimatedNumberOfKvsScanned() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Returns The estimated number of KVs seen by this scanner (includes some skipped KVs).
- getEstimatedUniquesFrac() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- getEvent(HttpServletRequest) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- getEvent() - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- getEvent() - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Retrieve event type for NamedQueueService implementation.
- getEventByOrdinal(int) - Static method in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
-
- getEventCount(int) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
- getEventLoopConfig(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
- getEventLoopConfig(Configuration) - Static method in class org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper
-
- getEventLoopGroupConfig() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Return the event type
- getEventType() - Method in interface org.apache.hadoop.hbase.procedure2.RSProcedureCallable
-
Event type used to select thread pool.
- getEventType() - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- getEventType() - Method in class org.apache.hadoop.hbase.replication.regionserver.ClaimReplicationQueueCallable
-
- getEventType() - Method in class org.apache.hadoop.hbase.replication.regionserver.RefreshPeerCallable
-
- getEventType() - Method in class org.apache.hadoop.hbase.replication.regionserver.SwitchRpcThrottleRemoteCallable
-
- getEvictCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getEvictedBlocks() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getEvictedFileCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the number of items evicted from the mob file cache.
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getEvictionThread() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getEvictionThread() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getExceedThrottleQuotaRowKey() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Returns the exception for the region, if any.
- getException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Get the value of the captured exception.
- getException() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- getException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getException() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- getException() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
Returns Null or the run exception; call this method after thread is done.
- getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Get the last exception which has occurred when re-setting the watch.
- getExceptionCount() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Get the exception that caused the snapshot to fail, if the snapshot has failed.
- getExceptionMessage() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getExceptionMessageAdditionalDetail() - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Returns Some details from the implementation that we would like to add to a terminating
exception; i.e.
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
n
- getExceptions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getExcludeDatanodeManager() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- getExcludeDatanodeManager() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getExcludeDNs() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
- getExcludedServersForSystemTable() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
For a given cluster with mixed versions of servers, get a list of servers with lower versions,
where system table regions should not be assigned to.
- getExcludeNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExcludeTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getExclusiveLockOwnerProcedure() - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- getExclusiveLockOwnerProcedure() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getExclusiveLockOwnerProcedure() - Method in interface org.apache.hadoop.hbase.procedure2.LockStatus
-
Get the procedure which holds the exclusive lock.
- getExclusiveLockProcIdOwner() - Method in interface org.apache.hadoop.hbase.procedure2.LockStatus
-
Return the id of the procedure which holds the exclusive lock, if exists.
- getExecString() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell
-
- getExecString() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine.DuFileCommand
-
- getExecutedWriteBufferPeriodicFlushes() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getExecutor() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getExecutor(ExecutorType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getExecutor(String) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getExecutor() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
-
- getExecutor() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
-
- getExecutorLazily(ExecutorService.ExecutorConfig) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getExecutorName(String) - Method in enum org.apache.hadoop.hbase.executor.ExecutorType
-
Returns Conflation of the executor type and the passed serverName
.
- getExecutorPoolName() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getExecutorService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns hbase executor service
- getExecutorServiceType() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- getExecutorThreadPool(ExecutorType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getExecutorType() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- getExeEx() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getExistingAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the favored nodes plan
- getExistingLabelsWithAuths() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
-
- getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getExpireBefore() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- getExpiredStores(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
-
- getExportFilter(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
- getExpression() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
Returns The visibility expression
- getExtendedAttribute(String) - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Return a named String value injected into the WALKey during processing, such as by a
coprocessor
- getExtendedAttribute(String) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getExtendedAttributes() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns a map of all extended attributes injected into this WAL key.
- getExtendedAttributes() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getExternalClassLoaders() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Retrieves the set of classloaders used to instantiate Coprocessor classes defined in external
jar files.
- getExternalDfsUri() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getExternalZkConnectString() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getExtraContextForError(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- getExtraFreeFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get an extra header value.
- getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get all extra headers (read-only).
- getFactor(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaUtil.KeyFromRow
-
- getFactory() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- getFactoryId() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getFailed() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- getFailed() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- getFailed() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Return the failed exception, null if not failed.
- getFailed() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- getFailedBatches() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- getFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- getFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the count of the failed bathes n
- getFailedCounter() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
-
- getFailedCounter() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureMetrics
-
Returns Total number of instances failed for a type of a procedure
- getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getFailedDeletions() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
Returns a set of failed deletions
- getFailedFiles() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
-
- getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getFailedInserts() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Returns any exception thrown during service method invocation, or null
if no exception
was thrown.
- getFailedOpen(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getFailedOperations() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getFailedOperations() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getFailedRegions() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getFailedServersFromLogFolders() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns failure count
- getFailureInfo() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- getFailureMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of check failure mob file paths after checkTables is called.
- getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of check failure file paths after checkTables is called.
- getFallBackCandidates(List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- getFallbackToSimpleAuth(SaslDataTransferClient) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslAdaptor
-
- getFamilies() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the keys of the familyMap
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getFamilies() - Method in enum org.apache.hadoop.hbase.MetaTableAccessor.QueryType
-
- getFamilies() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the set of families present on disk n
- getFamilies() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
For use by FSWALEntry ONLY.
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getFamily() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the family to check
- getFamily() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column family
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the family
- getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- getFamily() - Method in class org.apache.hadoop.hbase.tool.BulkLoadHFiles.LoadQueueItem
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the
containing array.
- getFamilyArray() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the column family bytes.
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getFamilyByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap n
- getFamilyDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular region dir, return all the familydirs inside it
- getFamilyLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of family bytes.
- getFamilyLength() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family length
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family length
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getFamilyLengthPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyLengthPosition(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyLengthPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyLengthPosition(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyLengthPosition(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyLengthPosition(int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap n
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap n
- getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
-
Before 0.95, when you called Increment#getFamilyMap(), you got back a map of families to a list
of Longs.
- getFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getFamilyNameInBytes() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getFamilyNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
Returns the family names which are effected by this edit.
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first family byte
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family offset
- getFamilyOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Family offset
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where column family bytes start
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyPosition(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getFamilyPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getFamilyStoreDirectoryPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getFamilyString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getFamilyToFilesMapping() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
-
- getFatalConnectionString(int, byte) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getFavoredNodeList(String) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getFavoredNodes(List<ServerName>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
n * @return PB'ed bytes of HBaseProtos.FavoredNodes
generated by the server list.
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Returns the list of favored region server for this region based on the plan
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- getFavoredNodes() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFavoredNodes() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getFavoredNodesAsString(List<ServerName>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getFavoredNodesForRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
Get the favored nodes mapping for this region.
- getFavoredNodesForRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Return the favored nodes for a region given its encoded name.
- getFavoredNodesList(byte[]) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Convert PB bytes to ServerName.
- getFavoredNodesManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getFavoredNodesManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Favored Nodes Manager
- getFavoredNodesWithDNPort(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getFavoredServerPosition(List<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Return the position of the server in the favoredNodes list.
- getField() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
-
- getField(List<Field>, String) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- getField() - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- getField() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- getFieldInfos() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- getFieldInfos() - Method in interface org.apache.hadoop.hbase.hbtop.mode.ModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
-
- getFieldInfos() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getFields() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getFieldValue(Field, String) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- getFieldValueType() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- getFifteenMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- getFifteenMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the fifteen-minute exponentially-weighted moving average rate at which events have
occurred since the meter was created.
- getFile(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getFileBeingSplit() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Exposed for Testing!
- getFileChannels() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- getFileChecksum(FileSystem, Path) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Return the file context of the HFile this reader belongs to
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Return the file context for the HFile this writer belongs to
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getFileCreateTime() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getFileDetails(Collection<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Extracts some details about the files to compact that are commonly needed by compactors.
- getFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getFileInfoHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getFileInfoHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getFileInfoMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getFileInfoMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFileLink(Path, Configuration) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- getFileList(List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- getFileList(Configuration, List<Path>, PathFilter) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
Get a list of paths that need to be split given a set of server-specific directories and
optionally a filter.
- getFilename() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- getFilename() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getFilename() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getFileName() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Gets the file name.
- getFileName() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the file name.
- getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getFileNode(String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getFileNode(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getFileNum(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getFileNumFromFileName(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getFilePath() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- getFilePath() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- getFilePath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getFilePath() - Method in class org.apache.hadoop.hbase.tool.BulkLoadHFiles.LoadQueueItem
-
- getFilePaths(FileSystem, Path, PathFilter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the file permissions specified in the configuration, if they are enabled.
- getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
-
n
- getFiles(FileSystem, Path, long, long) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- getFiles() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.SnapshotDirectoryInfo
-
Returns the hfiles in the snapshot when this was made.
- getFiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns unmodifiable collection of StoreFiles in compaction
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Get the backing files associated with this WAL.
- getFilesForScan(byte[], boolean, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getFilesForScan(byte[], boolean, byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the store files to scan for a Scan or Get request.
- getFilesForScan(byte[], boolean, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getFileSize(String) - Static method in class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
-
Using Linux command du to get file's real size
- getFileSize() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- getFileSize(FileSystem, String) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
Computes the size of a single file on the filesystem.
- GetFileSize() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetFileSize
-
- getFileSize(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getFileSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getFileSplitPoint(HStoreFile, CellComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets the approximate mid-point of the given file that is optimal for use in splitting it.
- getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Get the FileStatus of the referenced file.
- getFileStatus() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns The FileStatus
of the file
- getFileSystem() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
Returns the FileSystem
on which this file resides
- getFileSystem() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns FileSystem
being used by this region
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the underlying FileSystem
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.Server
-
Returns Return the FileSystem object used (can return null!).
- getFileSystem() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the filter to check
- getFilter() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Query
-
n
- getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
n
- getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns the Filter
- getFilter() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- getFilter() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns the filter specification
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterByFromThrift(TLogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getFilterByOperator() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getFilteredLogs(AdminProtos.SlowLogResponseRequest, List<TooSlowLog.SlowLogPayload>) - Static method in class org.apache.hadoop.hbase.namequeues.LogHandlerUtils
-
- getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of filtered read requests made to region
- getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getFilteredReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of filtered read requests that have been issued against this region
- getFilteredReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getFilteredReadRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of write requests that have been issued against this table
- getFilteredReadRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getFilteredReadRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- getFilteredReadRequests() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- getFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns count of filtered read requests for a user
- getFilteredReadRequests() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of filtered read requests to regions hosted on this region server.
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns filtered read requests count for this region
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getFilteredReadRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
-
- getFilteredReadRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- getFilterEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
The number of Bloom filter entries in this store file, or an estimate thereof, if the Bloom
filter is not loaded.
- getFilterHistories() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether entire row should be filtered if column is not found.
- getFilterInitializers(Configuration) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Get an array of FilterConfiguration specified in the conf
- getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the filter name given a simple filter expression
- getFilterParams(Configuration, String) - Static method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
Constructs a mapping of configuration properties to be used for filter initialization.
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the filters.
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- getFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getFinalFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getFinalParameters() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the table and column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a fingerprint which identifies the type and the static schema
components of a query (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the table and column family (i.e.
- getFirst(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the first node of the tree.
- getFirst() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
-
- getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns time of the fist failure
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getFirstKey() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the first key in this store file.
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- getFirstKeyCellInBlock(ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Return first key in block as a cell.
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- getFirstKeyCellInBlock(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
-
- getFirstKeyCellInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getFirstKeyCellInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getFirstLevelCache() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getFirstRegionInfo() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getFirstRegionInfo() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's patch goes in to
eliminate
KeyValue
here.
- getFiveMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- getFiveMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the five-minute exponentially-weighted moving average rate at which events have
occurred since the meter was created.
- getFlags() - Method in interface org.apache.hadoop.hbase.filter.RegexStringComparator.Engine
-
Returns the set of configured match flags, a bit mask that may include
Pattern
flags
- getFlags() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- getFlags() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- getFlattenAction() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- getFlattenAction() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- getFloat(String, float) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getFloat(Configuration, String, float, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Flush will first clear out the data in snapshot if any (It will take a second flush invocation
to clear the current Cell set).
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells flushed to disk.
- getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells flushed to disk
- getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data flushed to disk, in bytes.
- getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total size of data flushed to disk, in bytes
- getFlushedOutputFileSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedOutputFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total size of out output files on disk, in bytes
- getFlushPolicyClass(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Get FlushPolicy class for the given table.
- getFlushPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getFlushPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFlushPressure() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getFlushPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Deprecated.
- getFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- getFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the flush queue.
- getFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns reference to FlushRequester
- getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFlushThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFlushThroughputController() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the controller to avoid flush too fast
- getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- getForegroundColor() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getFormatVersion() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getFragmentationInfo(HMaster, Configuration) - Method in class org.apache.hadoop.hbase.master.http.MasterStatusServlet
-
- getFreeBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getFreeBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getFreeMemory() - Method in class org.apache.hadoop.hbase.util.JVM
-
Return the physical free memory (not the JVM one, as it's not very useful as it depends on the
GC), but the one from the OS as it allows a little bit more to guess if the machine is
overloaded or not).
- getFreeSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the free size of the block cache, in bytes.
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getFromCacheOrFetch() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
Fetches the ClusterId from FS if it is not cached locally.
- getFromHBase(Get) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getFromRegion() - Method in class org.apache.hadoop.hbase.master.balancer.SwapRegionsAction
-
- getFromServer() - Method in class org.apache.hadoop.hbase.master.balancer.MoveRegionAction
-
- getFromServer() - Method in class org.apache.hadoop.hbase.master.balancer.SwapRegionsAction
-
- getFromThrift(TGet) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
Get
(HBase) from a
TGet
(Thrift).
- getFs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the handle on the local file system
- getGauge(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a MetricMutableGaugeLong from the storage.
- getGaugeInt(String, int) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a MetricMutableGaugeInt from the storage.
- getGcCollectorBeans() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getGcTimes() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- getGeneralBloomFilter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getGeneralBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves general Bloom filter metadata as appropriate for each
HFile
version.
- getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns a buffer with the Bloom filter metadata.
- getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getGeneralBloomMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getGeneralBloomMetaHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getGeneralBloomMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getGeneralBloomMetaMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getGeneralBloomWriter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
For unit testing only.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- getGeneralQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the general queue for metrics.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getGlobalLimiter() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Return the limiter associated with this quota.
- getGlobalLimiterWithoutUpdatingLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Return the limiter associated with this quota without updating internal last query stats
- getGlobalMemStoreDataSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global Memstore data size in the RegionServer
- getGlobalMemStoreHeapLowerMark(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve configured size for global memstore lower water mark as fraction of global memstore
size.
- getGlobalMemStoreHeapPercent(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Retrieve global memstore configured size as percentage of total heap.
- getGlobalMemStoreHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global memstore heap size in the RegionServer
- getGlobalMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalMemStoreLimitLowMark() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalMemStoreLimitLowMarkPercent() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalMemStoreOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the global memstore heap size in the RegionServer
- getGlobalMemStoreSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Returns Pair of global memstore size and memory type(ie.
- getGlobalMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getGlobalOffHeapMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalOnHeapMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalPermissions(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- getGlobalRootPaths() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
return paths that user will global permission will visit
- getGlobalSource() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getGlobalSource() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getGlobalTracer() - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
- getGroupAdminServer() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- getGroupAuths(String[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getGroupAuths(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getGroupAuths(String[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the groups.
- getGroupAuthsAsOrdinals(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the groups n * @return the list of
ordinals
- getGroupInfoManager() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Returns the actual name for a group principal (stripped of the group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- getGroups(String) - Method in class org.apache.hadoop.hbase.security.User.TestingGroups
-
- getGroups() - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
- getGuaranteedClientSideOnly() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
-
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
-
- getHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Override if providing alternate Handler implementation.
- getHashCount() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- getHashType() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts the name of the configured hash type to a symbolic constant.
- getHBase1CompatibleName(String) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getHBaseServerWrapper() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the HBase version string as reported by the HMaster
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
Returns the HBase version string as reported by the HMaster
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Returns the HBase release
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the HBase version as a string (e.g.
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- getHbck() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getHbck() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck(ServerName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Hbck implementation to fix an HBase cluster.
- getHbck() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getHbck() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getHbckChore() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getHbckInternal(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getHbckLockPath() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.FileLockCallable
-
Deprecated.
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
Get the HDFSBlocksDistribution derived from the StoreFile input stream, re-computing if cache
is expired.
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns the HDFS block distribution
- getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getHdfsEntry() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getHdfsHRI() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getHdfsRegionDir() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getHead() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- getHeader() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- getHeader() - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- getHeader(ByteBuf, int) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- getHeader() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The request header of this call.
- getHeader() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getHeader() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeader(String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Returns the value of a header.
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
- getHeaderAndDataForTest() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Returns the header or the compressed data (or uncompressed data when not using compression)
as a byte array.
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the HTTP response headers
- getHeaderSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- getHealthReport(HealthChecker.HealthCheckerExitStatus) - Method in class org.apache.hadoop.hbase.HealthChecker
-
- getHealthReport() - Method in class org.apache.hadoop.hbase.HealthReport
-
Gets the health report of the region server.
- getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Returns the current Heap
- getHeapAllocationBytes() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getHeapAllocationBytes(ByteBuffAllocator...) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getHeapAllocationRatio(ByteBuffAllocator...) - Static method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Get a MetricsHeapMemoryManagerSource
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns heap memory manager instance
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
Returns heap occupancy percentage, 0 <= n <= 1.
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns The heap size of this segment.
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- getHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the heap size of this batch
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the current heap size, in MB
- getHeapSizeProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getHedgedReadOps() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of hedged read operations
- getHedgedReadOps() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getHedgedReadOpsInCurThread() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of times a hedged read executes in current thread
- getHedgedReadOpsInCurThread() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getHedgedReadWins() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Count of times a hedged read beat out the primary read.
- getHedgedReadWins() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getHFileCleaners() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getHFileCleanerScanPool(Configuration) - Static method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- getHFileCleanerScanPool(String) - Static method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
-
Returns HFile meta information
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Returns HFile context information
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getHFileFromBackReference(Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileFromBackReference(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getHFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getHFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getHFileLinkPatternRelativePath(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Convert a HFileLink path to a table relative path.
- getHFileMinorVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
Returns The hfileName portion of this cache key
- getHFileName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getHFileNames(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the store file names in the snapshot.
- getHFileNames(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the store file names in the snapshot.
- getHFileNode(String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getHFilePath(TableName, WALProtos.BulkLoadDescriptor, String, byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- getHFileReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getHFileRefsPeerNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getHFileRefsZNodeCversion() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns number of hfiles checked in the last HfileCorruptionChecker run
- getHFilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getHFilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of only the store files which are HFiles, in bytes.
- getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getHFileWriter() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
For use in testing.
- getHfs() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getHighest(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Private internal method that returns the higher of the two key values, or null if they are both
null
- getHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- getHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- getHistogram() - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
-
- getHistogram() - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
- getHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- getHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns a summary of hist
.
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getHitCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitRatio() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the hit ratio to the mob file cache.
- getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHMAC(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- getHoleCover(Pair<RegionInfo, RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- getHoles() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the host name
- getHost() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Returns the hosts and their weights
- getHostInetAddress() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getHostName() - Static method in class org.apache.hadoop.hbase.chaos.ChaosUtils
-
- getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns null if not set
- getHostName() - Method in class org.apache.hadoop.hbase.net.Address
-
- getHostname() - Method in class org.apache.hadoop.hbase.net.Address
-
- getHostName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- getHostName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostName() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
-
- getHostName() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- getHostname(Configuration, DNS.ServerType) - Static method in class org.apache.hadoop.hbase.util.DNS
-
Get the configured hostname for a given ServerType.
- getHostnameForServerPrincipal(Configuration, InetAddress) - Static method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- getHostnameLowerCase() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostNameMinusDomain(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostsForLocations(LocatedBlock) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getHotWindowAgeMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getHotWindowStoragePolicy() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
Returns the HRegionInfo for the current region
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Returns the HRegionInfo for the current region
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- getHriList() - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
-
- getHris() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getHTableDescriptor(TableName, Connection, RpcRetryingCallerFactory, RpcControllerFactory, int, int) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getHTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2.TableInfo
-
- getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
Returns the current HTableMultiplexerStatus
- getHtd() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the wrapped HttpClient
- getHttpClient() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getHttpServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
the Jetty server, not null means the HTTP server is started, for test only
- getId() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to retrieve the identifier for the operation if one was set.
- getId() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns The id of a data block encoder.
- getId() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getId() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- getId() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns snapshot's identifier.
- getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Returns the encoded region id
- getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getIfCached(Path) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getIfPresentOrNew() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
- getImmutableSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getImplementationClassName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Returns Name of the class we will use when we construct a
BufferedMutator
instance or
null if default implementation.
- getIncludedTables() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getIncomingWindow(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- getInconsistentRegions() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
The inconsistent regions.
- getIndex(long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- getIndexBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getIndexChunksPool() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getIndexStatistics(BucketAllocator.IndexStatistics) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getIndexStatistics() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getIndexType() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getIndividualAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getInflightWALCloseCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns number of WALs currently in the process of closing.
- getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Returns the security configuration associated with the given service name.
- getInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getInfoPort() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- getInformativeName() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event implementations should override thie class to provide an informative name about what
event they are handling.
- getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns the info server
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getInfoServerPort() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getInheritedFNForDaughter(FavoredNodeAssignmentHelper, List<ServerName>, FavoredNodesPlan.Position, FavoredNodesPlan.Position) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- getInheritedFNForDaughter(FavoredNodeAssignmentHelper, List<ServerName>, FavoredNodesPlan.Position, FavoredNodesPlan.Position) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- getInitialCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getInitialDelay(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Extracts the initial delay for the chore from the configuration.
- getInitialDelay(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Extracts the initial delay for the chore from the configuration.
- getInitialDelay(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
Extracts the initial delay for the chore from the configuration.
- getInitialDelay(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Extracts the initial delay for the chore from the configuration.
- getInitialDelay(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Extracts the initial delay for the chore from the configuration.
- getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns initial delay before executing chore in getTimeUnit() units
- getInitialFilters() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
-
- getInitialFunctionCosts() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getInitializedEvent() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getInitializedEvent() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Tripped when Master has finished initialization.
- getInitialResponse() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Return the initial state object that will be used for the first call to executeFromState().
- getInitialState() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getInitTotalCost() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getInlineBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
The type of blocks this block writer produces.
- getInMemoryCompaction() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns in-memory compaction policy if set for the cf.
- getInMemoryCompaction() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getInMemoryCompaction() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getInMemoryCompactionPool() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getInMemoryCompactionPoolForTest() - Static method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getInmemoryFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getInputPaths(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- getInputStream() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- getInputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getInputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped InputStream.
- getInputStreamWrapper() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- getInstance() - Static method in interface org.apache.hadoop.hbase.CellComparator
-
A comparator for ordering cells in user-space tables.
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
-
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilitySingletonFactory
-
Get the singleton instance of Any classes defined by compatibiliy jar's
- getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the loaded coprocessor instance
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- getInstance() - Static method in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
Returns an instance of this factory.
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance(int, int) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- getInstance() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Returns the RESTServlet singleton instance
- getInstance(Configuration, UserProvider) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getInstance(MasterServices) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
- getInstance() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a given type.
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a type defined in the configuration.
- getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
-
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash3
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getInstances(String, Class<U>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getInt(String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- getInt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the int value at the current position.
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the int at the given index.
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the int at the given index.
- getInt(int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getInt() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the int value at the current position.
- getInt() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getInt(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getInt(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getInt() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the int value at index
- getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next int value from this range.
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the int value at the given offset from current position.
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getIntAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getInteger(HttpServletRequest, String, Integer) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getIntermediateIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getIntermediateIndexHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getIntermediateIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getIntermediateIndexMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getInternal(Get, boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getInternalName() - Method in enum org.apache.hadoop.hbase.http.ProfileServlet.Event
-
- getInts(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getIoEngine() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getIOEngineFromName(String, long, String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Get the IOEngine from the IO engine name nnn * @return the IOEngine n
- getIOError(Throwable) - Static method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getIOHitsPerSecond() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIOTimePerHit() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIp4Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIp6Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIpAddress() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIpAddress(Addressing.AddressSelectionCondition) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIpAddressBytes() - Static method in class org.apache.hadoop.hbase.client.ClientIdGenerator
-
Returns Some IPv4/IPv6 address available on the current machine that is up, not virtual and not
a loopback address.
- getIsActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Whether this master is the active master
- getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns The isolation level of this query.
- getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getItemAllocationSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getItemByteBuffer(ByteBuff, int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getItemByteBufferCount(ByteBuff) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getItemIndex(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getItemIndexForByteBuff(ByteBuff, int, int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getItemIndexFromCurItemIndex(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getIterator(int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Provides access to compressed value.
- getIterator(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- getIterator() - Method in class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the initialization vector
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the expected initialization vector length, in bytes, or 0 if not applicable
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the expected length for the initialization vector
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the expected length for the initialization vector
- getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
Returns the full path to the Jar containing the class.
- getJar(Class<?>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Invoke 'getJar' on a custom JarFinder implementation.
- getJarPath() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Path of the jar file.
- getJarPath() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- getJasonProvider() - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Get the JacksonJaxbJsonProvider
instance;
- GetJavaProperty - Class in org.apache.hadoop.hbase.util
-
A generic way for querying Java properties.
- GetJavaProperty() - Constructor for class org.apache.hadoop.hbase.util.GetJavaProperty
-
- getJCECipherInstance() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
Returns the version of the embedded Jersey framework
- getJitter() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getJumboChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Creates and inits a chunk of a special size, bigger than a regular chunk size.
- getJVMSpecVersion() - Static method in class org.apache.hadoop.hbase.util.JVM
-
- getJVMVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
Returns the JVM vendor and version
- getKeepAliveMasterService() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getKeepAliveTime(TimeUnit) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getKeepAliveTimeMillis() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns return the KeepDeletedCells
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getKeepDeletedCells() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- getKeepProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getKey(int) - Method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve the key for a given key aliase n * @return the keys corresponding to the supplied
alias, or null if a key is not found
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKey() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- getKey() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
From the current position creates a cell using the key part of the current buffer
- getKey() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets the current key in the form of a cell.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue
-
Do not use unless you have to.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKey() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- getKey() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.BufferNode
-
- getKey() - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteNode
-
- getKey() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapEntry
-
- getKey() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
Returns the row key
- getKey() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getKey(int) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getKey() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.COWEntry
-
- getKey() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the key n
- getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
- getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns The number of keys added to the bloom
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- getKeyDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up in its underlying data structure for the key.
- getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyForNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- getKeyFromConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getKeyFromRow(byte[]) - Method in interface org.apache.hadoop.hbase.quotas.QuotaUtil.KeyFromRow
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the key length required by this cipher, in bytes
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Length of key portion.
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
-
- getKeyNode(int) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Key offset in backing buffer..
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getKeys() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
-
- getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve keys for a given set of key aliases
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeysAndRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding start keys and regions for an arbitrary range of keys.
- getKeysAndRegionsInRange(byte[], byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding start keys and regions for an arbitrary range of keys.
- getKeysParentZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
get token keys parent node
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Returns a count of all KeyValues in the region where this coprocessor is loaded.
- getKeyValueDataStructureSize(int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueDataStructureSize(int, int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueForClass(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Get the kv
Map.Entry
in the descriptor for the specified class
- getKeyValues(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getKeyValues(Configuration, String, char) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
Retrieve a list of key value pairs from configuration, stored under the provided key
- getKind() - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeTokenIdentifier
-
- getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKVBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getL1CacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks in L1 cache
- getL1CacheCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks evicted from L1 cache
- getL1CacheEvictedCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Free cache size (bytes) of L1 cache
- getL1CacheFreeSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit count of L1 cache.
- getL1CacheHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit ratio of L1 cache.
- getL1CacheHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss count of L1 cache.
- getL1CacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss ratio of L1 cache.
- getL1CacheMissRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL1CacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Cache size (bytes) of L1 cache
- getL1CacheSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks in L2 cache
- getL2CacheCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of blocks evicted from L2 cache
- getL2CacheEvictedCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Free cache size (bytes) of L2 cache
- getL2CacheFreeSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit count of L2 cache.
- getL2CacheHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheHitRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Hit ratio of L2 cache.
- getL2CacheHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss count of L2 cache.
- getL2CacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheMissRatio() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Miss ratio of L2 cache.
- getL2CacheMissRatio() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getL2CacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Cache size (bytes) of L2 cache
- getL2CacheSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getLabel(int) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
Returns the string associated with the ordinal.
- getLabel(int) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabelOrdinal(String) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
- getLabelOrdinal(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabelOrdinals(ExpressionNode, List<Integer>, Set<Integer>, boolean, VisibilityLabelOrdinalProvider) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getLabels() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getLabels() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.ScanLabelGenerator
-
Helps to get a list of lables associated with an UGI nn * @return The labels
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getLabelsCount() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns The total number of visibility labels.
- getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getLargeCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getLargeCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getLargeLogPayloads(AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- getLargeLogResponses(RpcController, AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getLargeQueueInitSize() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getLargestFile(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets the largest file (with reader) out of the list of files.
- getLargestQueueFromServersNotCompacting() - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- getLast(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Return the last node of the tree.
- getLastAppliedOpAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- getLastAppliedOpAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns time of the latest attempt
- getLastCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getLastCell() - Method in class org.apache.hadoop.hbase.util.BloomContext
-
- getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getLastCompactSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns aggregate size of all HStores used in the last compaction
- getLastContact() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLastestPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLastFullCompute() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- getLastGcDuration(ObjectName) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getLastHost() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getLastIndexExclusive() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getLastKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getLastKey() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the last key in this store file.
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getLastKeyCell() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getLastKeyUpdate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getLastMajorCompactionAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Age of the last major compaction
- getLastMajorCompactionAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed table The timestamp of the oldest
HFile resulting from a major compaction of that table, or 0 if no such HFile could be found.
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed table.
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLastMajorCompactionTimestamp() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getLastMajorCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the timestamp of the oldest hfile for any store of this region.
- getLastMajorCompactionTimestamp() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
n * @return the timestamp of the last successful major compaction for the passed region or 0 if
no HFile resulting from a major compaction exists n
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastPeekedCell() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getLastProcId() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLastRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
Get last region this RpcChannel communicated with
- getLastRegionServerUpdate() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the timestamp at which the last change occurred to the list of region servers to replicate
to.
- getLastReport() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
Returns Returns last published Report that comes of last successful execution of this chore.
- getLastReport() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
Returns Returns last published Report that comes of last successful scan of hbase:meta.
- getLastReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getLastReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the last timestamp (server side) of generating this metrics
- getLastReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's patch goes in to
eliminate
KeyValue
here.
- getLastRowKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getLastSegment() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getLastSeqIds() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the last sequenceid for each region if the table has serial-replication scope
- getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
-
- getLastSequenceId(String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getLastSequenceId(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Read the max sequence id of the specific region for a given peer.
- getLastSequenceId(String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getLastSequenceIdWithVersion(String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
Return the {lastPushedSequenceId, ZNodeDataVersion} pair.
- getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getLastShippedAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getLastShippedAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSource
-
- getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getLastTouched() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- getLastTxid(Deque<FSWALEntry>) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLastWalPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the path of the last WAL that was read.
- getLastWalPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the position in the last WAL that was read.
- getLatch() - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getLeafIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getLeafIndexHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getLeafIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getLeafIndexMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getLeaseManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLeaseManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The RegionServer's "Leases" service
- getLeaseName() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager.Lease
-
Returns the lease name
- getLeastFilledBuckets(Set<Integer>, int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Returns a set of indices of the buckets that are least filled excluding the offsets, we also
the fully free buckets for the BucketSizes where everything is empty and they only have one
completely free bucket as a reserved
- getLeft() - Method in class org.apache.hadoop.hbase.master.janitor.MetaFixer.Either
-
- getLeftoverRegions() - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Returns an
Iterator
over the Regions which were skipped last invocation of the chore.
- getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
The HFileV2 file format's trailer contains this class name.
- getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
The HFileV2 file format's trailer contains this class name.
- getLength(byte[], int) - Static method in class org.apache.hadoop.hbase.ArrayBackedTag
-
- getLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Header
-
- getLength() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns the number of valid bytes in the buffer
- getLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getLength(byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Determines the total length of the KeyValue stored in the specified byte array and offset.
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Returns the length
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- getLength() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotInputSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Retrieve the maximum length (in bytes) of encoded values.
- getLength() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The length of the range.
- getLength() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the number of valid bytes in the buffer
- getLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.WriterBase
-
- getLevel(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- getLevel(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec.HadoopLz4Compressor
-
- getLevel(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec.HadoopLzoCompressor
-
- getLevel(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec.HadoopSnappyCompressor
-
- getLevel(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec.HadoopZstdCompressor
-
- getLevel(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getLevel(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- getLevel(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- getLevel0Copy() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
Returns A lazy L0 copy from current state.
- getLevel0Files() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Returns Level 0 files.
- getLevel0Files() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getLevel0MinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getLexicalErrorMessage(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getLimit() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getLimit() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the limit of rows for this scan
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getLimit() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the limit, in bytes, of the target (e.g.
- getLimit() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Return the current limit n
- getLineBytes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getListener() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager.Lease
-
Returns listener
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcSchedulerContext
-
- getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Return the socket (ip+port) on which the RPC server is listening to.
- getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get a copy of current registered listeners
- getListOfRegionInfos(List<Pair<RegionInfo, ServerName>>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all region servers that have outstanding replication queues.
- getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getListOfReplicators0() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getLiveNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Returns the list of live nodes
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLiveRegionServers(ZKWatcher) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- getLiveServerLoads() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getLiveServerMetrics() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the live list
- getLiveServerMetrics() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getLiveServerMetrics() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getLiveServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getLiveServers() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource.ClusterMetricsResource
-
- getLiveServersFromWALDir() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Get Servernames that COULD BE 'alive'; excludes those that have a '-splitting' suffix as these
are already being split -- they cannot be 'alive'.
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLoad() - Method in class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
n * @return ServerMetrics if serverName is known else null
- getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getLoadAverage() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getLoadBalancer(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
Create a loadbalancer from the given conf.
- getLoadBalancer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLoadBalancer() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns load balancer
- getLoadBalancerClassName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Query
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLoadedCachedBlocksByFile(Configuration, BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.master.HMaster
-
The set of loaded coprocessors is stored in a static set.
- getLoadOnOpenBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the load sequence number
- getLoadStatistics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns statistics about the current load of the region
- getLocalBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getLocalBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read from the local HDFS DataNode.
- getLocalBytesRead() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getLocalConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a LocalFileSystem within a HFileSystem.
- getLocalityOfRegion(int, int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- getLocallyCachedPolicies() - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
Returns an unmodifiable version of the policy enforcements that were cached because they are
not in violation of their quota.
- getLocalPath(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getLocalTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
nn * @return All the table directories under rootdir
.
- getLocateType(Scan) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- getLocation() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- getLocation(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getLocation() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Returns the value of the Location header
- getLocation() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Returns the name and port of the region server hosting the region
- getLocationForReplica(RegionLocations) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
-
Returns the locations to look for the linked file.
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- getLocations(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getLocations() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotInputSplit
-
- getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getLocator() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getLocator(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getLock(Map<T, LockAndQueue>, T) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getLock() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- getLock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getLock(T) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
Get the ReentrantReadWriteLock corresponding to the given id
- getLockedRows() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Blocks until the lock corresponding to the given id is acquired.
- getLockForNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- getLockManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLockManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLockResource(LockedResourceType, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getLockResource(LockedResourceType, String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getLockResource(LockedResourceType, String) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
- getLockResource(LockedResourceType, String) - Method in class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- getLocks() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get locks.
- getLocks() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List locks.
- getLocks() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getLocks() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLocks() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getLocks(RpcController, MasterProtos.GetLocksRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLocks() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLocks(RpcController, MasterProtos.GetLocksRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLocks() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get locks
- getLocks() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getLocks() - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
List lock queues.
- getLocks() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
List lock queues.
- getLocks() - Method in class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- getLocks() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getLockStatus() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- getLockType() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getLogCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLogCleanerScanPool(Configuration) - Static method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are stored by their RSs
- getLogDirs(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve recent online records from HMaster / RegionServers.
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Retrieve recent online records from HMaster / RegionServers.
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getLogEntries(RpcController, HBaseProtos.LogRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getLogEntries(RpcController, HBaseProtos.LogRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLogEntries(RpcController, HBaseProtos.LogRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getLogEntries(Set<ServerName>, String, ServerType, int, Map<String, Object>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getLogFileName() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- getLogFilePath(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getLogFiles() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the size of log files in use
- getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the
size of files (only rolled).
- getLogFileSize(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
returns the size of rolled WAL files.
- getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- getLogFileSize() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- getLogFileSize() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Get size of the log files this provider is managing
- getLogFileSizeIfBeingWritten(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
if the given path
is being written currently, then return its length.
- getLogFileSizeIfBeingWritten(Path) - Method in interface org.apache.hadoop.hbase.replication.regionserver.WALFileLengthProvider
-
- getLogFileSizeIfBeingWritten(Path) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- getLogger(TableName, long) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- getLogId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getLogIdFromName(String) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getLoginContext() - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
To authenticate the demo client, kinit should be invoked ahead.
- getLogMessageDetail(int, Path, long) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
Returns Detail to append to any log message around lease recovering.
- getLogReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This method gets the datanode replication count for the current WAL.
- getLogReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- getLogReplication() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This method gets the datanode replication count for the current WAL.
- getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available log files
- getLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total log size
- getLogType(RpcLogDetails) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- getLogTypeFromThrift(TLogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getLong(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getLong(HttpServletRequest, String) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getLong() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the long value at the current position.
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the long at the given index.
- getLong(int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the long at the given index.
- getLong() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the long value at the current position.
- getLong() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getLong(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
- getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value from this range.
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the long value at the given offset from current position.
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getLongAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getLongBytes(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getLongCompactions() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the longCompactions thread pool executor
- getLongFromSnapshotProps(Map<String, Object>, String) - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getLongValue(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
Returns Get the long out of the passed in Cell
- getLongValue() - Method in class org.apache.hadoop.hbase.Size
-
get the value
- getLowest(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getLowestLocalityRegionOnServer(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- getLowestSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
Returns the lowest unflushed sequence id for the region.
- getLowestSequenceId(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- getLowestSequenceId(Map<?, Long>) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- getLowestTimestamp(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets lowest timestamp from candidate StoreFiles
- getLruCacheStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during major compactions.
- getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The number of cells processed during major compactions
- getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during major compactions, in bytes.
- getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The total amount of data processed during major compactions, in bytes
- getMajorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for major compactions.
- getMajorCompactionCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMajorCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMajorCompactionJitter() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorCompactionPeriod() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorCompactionRequest(RegionInfo) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- getMajorCompactionRequest(RegionInfo) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the major version of this HFile format
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getMajorVersion(String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- getManager() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMapForTests() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getMapForTests() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Get the application's mapper class.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current active master.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getMaster() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getMaster() - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
-
- getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMaster() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
Returns the master value
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns the HMaster thread
- getMaster() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getMaster() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
Returns the master
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster became the active master.
- getMasterAddr(Configuration) - Static method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
Builds the default master address end point if it is not specified in the configuration.
- getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master address.
- getMasterAddressTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Master address tracker instance.
- getMasterConfiguration() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Helper that delegates to getClusterMetrics().getMasterCoprocessorNames().
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getMasterCoprocessorNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterCoprocessorNames() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getMasterCoprocessorNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns array of coprocessor SimpleNames.
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterFinishedInitializationTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster finished becoming the active master
- getMasterImplementation(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterIndex(ServerName) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the current master of one is available.
- getMasterInfoPort(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master info port.
- getMasterInitializationTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the time in Millis when the master finished initializing/becoming the active master
- getMasterInitializationTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getMasterMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterMetrics() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns detailed information about the current master
ServerName
.
- getMasterName() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getMasterName() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterName() - Method in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- getMasterObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessor
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- getMasterObserver() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterProcedureExecutor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterProcedureManagerHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the underlying MasterProcedureManagerHost
- getMasterProcedureManagerHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the underlying MasterProcedureManagerHost
- getMasterProto(byte[]) - Static method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getMasterQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterQuotaManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterQuotaManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- getMasterRegion() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasters() - Method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns Read-only list of master threads.
- getMasters(RpcController, RegistryProtos.GetMastersRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.HasMasterServices
-
Deprecated.
Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
- getMasterServices() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors
-
- getMasterServices() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns timestamp in millis when HMaster was started.
- getMasterStub() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getMasterTasks() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Provide the list of master tasks
- getMasterTasks() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getMasterTasks() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getMasterWalManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterWalManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMax() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the biggest timestamp that should be considered
- getMax() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getMax() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- getMax() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the highest value in the snapshot.
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Returns the maximumTimestamp
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- getMax() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- getMax() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getMaxBalancingTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns Maximum time we should run balancer for
- getMaxCachedBlocksByFile(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- getMaxCacheSize() - Method in class org.apache.hadoop.hbase.CacheEvictionStats
-
- getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the max column range for the filter
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if max column is inclusive, false otherwise
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the max reference count for any store file among all compacted stores files of this
region
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns get maximum ref count of storeFile among all compacted HStore Files for the HStore
- getMaxCompactedStoreFileRefCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the max number of references active on any store file among all compacted store files
that belong to this region
- getMaxCompactedStoreFileRefCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMaxCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getMaxCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns upper bound on file size to be included in minor compactions
- getMaxCompactSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMaxCost(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- getMaxCount() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getMaxCount(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getMaxCount() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- getMaxFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of the maximum file descriptors the system can use.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getMaxFileSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region split is
triggered.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region split is
triggered.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the maximum size upto which a region can grow to after which a region split is
triggered.
- getMaxFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns upper bound on number of files to be included in minor compactions
- getMaxFlushedSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMaxFlushedSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMaxFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getMaxFlushQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns the value for Bloom filter max fold in the given configuration
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMaxHeapSize() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getMaxHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the maximum allowable size of the heap
- getMaxHeapSize() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the maximum heap size, in MB
- getMaximumAllowedTimeBetweenRuns() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns max allowed time in millis between runs.
- getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getMaximumTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the max timestamp of all the cells in the store file.
- getMaxKeys() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
- getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Returns The max number of keys that can be inserted to maintain the desired error rate
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns max key for the Bloom filter from the configuration
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Returns maxKeyValueSize from configuration.
- getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getMaxLoad() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getMaxLogId(FileStatus[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getMaxMasterTimeout(Configuration, SnapshotProtos.SnapshotDescription.Type, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getMaxMemory() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
Returns the max memory of the process.
- getMaxMemStoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxMemStoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getMaxMemStoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The maximum memstoreTS in all store files.
- getMaxMemStoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get max of the MemstoreTS in the KV's in this store file.
- getMaxMemStoreTSInList(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Return the largest memstoreTS found across all storefiles in the given list.
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getMaxModifiedProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- getMaxMultiSizeLimit() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Returns the maximum size (in bytes) that should be included in any single multi() call.
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getMaxPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxPriority() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getMaxQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxRegions(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getMaxRegionSequenceId(Configuration, RegionInfo, ConcurrentMapUtils.IOExceptionSupplier<FileSystem>, ConcurrentMapUtils.IOExceptionSupplier<FileSystem>) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getMaxRegionSequenceId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Get the max sequence id which is stored in the region directory.
- getMaxRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns Maximum number of regions in transition
- getMaxReplicaId(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Returns Maximum region replica id found in passed list of regions.
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the maximum result size in bytes.
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of values to return per Column Family
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns maximum number of values to return per row per CF
- getMaxRetries() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMaxRetryInQueue() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The maximum sequence id in all store files.
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns This files maximum edit sequence id.
- getMaxSequenceId(FileStatus[]) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getMaxSequenceIdInList(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Return the highest sequence ID found across all storefiles in the given list.
- getMaxSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the Max size of the block cache, in bytes.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get the maximum size of this cache.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the maximum size of this cache.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache.HFileBlockTranscoder
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getMaxSkew(double, double) - Static method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
Return the max deviation of distribution Compute max as if all region servers had 0 and one had
the sum of all costs.
- getMaxSleepTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getMaxSplitImbalance() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Max age of store files hosted on this region server
- getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Max age of store files under this region
- getMaxStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMaxStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Max age of store files for this table
- getMaxStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMaxStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Max age of store files in this store
- getMaxStoreFileRefCount(Configuration) - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- getMaxStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the max number of store files across all regions of this region server.
- getMaxStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMaxStoreFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the max number of store files across all regions of this table
- getMaxStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMaxStoreSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMaxStoreSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMaxTables(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getMaxThroughput() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- getMaxTierAgeCutoff(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
-
- getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- GetMaxTimestamp() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetMaxTimestamp
-
- getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getMaxTrailerSize() - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
returns the maximum value for this type T n
- getMaxValues() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns maximum number of versions
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of version
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the max number of versions to fetch
- getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns maximum number of versions to return
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getMaxWaitTime() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- getMBeanAttributeInfo(ObjectName) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns in MD5 hash as a hex string.
- getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns its MD5 hash as a hex string.
- getMean() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMean() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- getMean() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getMean() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the arithmetic mean of the values in the snapshot.
- getMean() - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Returns mean of the data values that are in the current list of data values
- getMeanRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- getMeanRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the mean rate at which events have occurred since the meter was created.
- getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Return the SASL mechanism name
- getMechanismName() - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- getMechanismNames(Map<String, ?>) - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer.SaslPlainServerFactory
-
- getMedian() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the median value in the distribution.
- getMemberName() - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Each subprocedure is being executed on a member.
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getMemoryFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMemoryLayout() - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
- getMemoryPools() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getMemstore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns MemStore Instance to use in this store.
- getMemStoreDataSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreDataSize(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Returns Return memstore data size or null if r
is null
- getMemStoreDataSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMemStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getMemStoreFlushSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
Returns Gets the Memstore flush size for the region that this store works with.
- getMemStoreHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreHeapSize(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Returns Return memstore heap size or null if r
is null
- getMemStoreHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMemStoreLAB() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the off heap memstore (if enabled), otherwise get the limit size of the
on heap memstore.
- getMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMemstoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreLoad() - Method in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- getMemStoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getMemStoreOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreOffHeapSize(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Returns Return memstore offheap size or null if r
is null
- getMemStoreOffHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMemstoreOnlyRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemstoreOnlyRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of row reads completely on memstore per store
- getMemstoreOnlyRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMemstoreOnlyRowReadsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns number of row reads completely from memstore per store for this table
- getMemstoreOnlyRowReadsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMemstoreOnlyRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the number of read requests purely from the memstore.
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the memstore size
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the memstore on this region server.
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the size of the memstore on this region server.
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMemStoreSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the memory store size against this table
- getMemStoreSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of this store's memstore.
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns memstore size, in MB
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMergedMemStoreLAB(Configuration, List<ImmutableSegment>) - Method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- getMergedRegion() - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Returns The merged region.
- getMergedRegions() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getMergeMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getMergeMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getMergeMinRegionAge() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- getMergeMinRegionAge() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergeMinRegionAge(SimpleRegionNormalizer.NormalizeContext) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergeMinRegionCount() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- getMergeMinRegionCount() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergeMinRegionCount(SimpleRegionNormalizer.NormalizeContext) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergeMinRegionSizeMb() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- getMergeMinRegionSizeMb() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergeMinRegionSizeMb(SimpleRegionNormalizer.NormalizeContext) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- getMergePlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of region merge plans executed.
- getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- getMergePlanCount() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- getMergeProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for merge procedure
- getMergeRegionInfo() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getMergeRegions(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns Return all regioninfos listed in the 'info:merge*' columns of the
regionName
row.
- getMergeRegions(Cell[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns Deserialized regioninfo values taken from column values that match the regex
'info:merge.*' in array of cells
.
- getMergeRegionsWithName(Cell[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that
match the regex 'info:merge.*' in array of cells
.
- getMergesDir(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getMergingAction() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- getMergingAction() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- getMessage() - Method in exception org.apache.hadoop.hbase.backup.FailedArchiveException
-
- getMessage(String, int, List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- getMessage(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getMessage() - Method in exception org.apache.hadoop.hbase.master.procedure.ServerCrashException
-
- getMessage() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- getMessage() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- getMessages() - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
- getMetaAssignEvent(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getMetaBlock(String, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getMetaBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getMetaBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getMetaBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getMetaData(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
For use by bucketcache.
- getMetadataValue(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getMetaEntry() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getMetaForRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMetaHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMetaHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getMetaHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMetaHTable(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Callers should call close on the returned
Table
instance.
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getMetaKeyForRegion(RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the row key to use for this regionInfo
- getMetaLocationOrNull(HMaster) - Method in class org.apache.hadoop.hbase.master.http.MasterStatusServlet
-
- getMetaLocationSyncer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMetaLocationSyncer() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get the meta location syncer.
- getMetaLock() - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getMetaLookupPool() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMetaMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMetaMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getMetaMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaOperationTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMetaOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.MetaProcedureInterface
-
Deprecated.
- getMetaPoolName() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getMetaPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the meta priority queue for metrics.
- getMetaPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getMetaProto(byte[]) - Static method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getMetaProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Called when we lazily create a hbase:meta WAL OR from ReplicationSourceManager ahead of
creating the first hbase:meta WAL so we can register a listener.
- getMetaQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getMetaReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaReadRpcTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMetaRegionFromName(byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getMetaRegionInfoIfToBeMoved(List<RegionInfo>) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- getMetaRegionLocation(CompletableFuture<RegionLocations>, List<String>) - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getMetaRegionLocation(int) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Gets the HRegionLocation for a given meta replica ID.
- getMetaRegionLocation(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegionLocation(ZKWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegionLocationCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- getMetaRegionLocations() - Method in interface org.apache.hadoop.hbase.client.ConnectionRegistry
-
Get the location of meta region(s).
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getMetaRegionLocations() - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.
- getMetaRegionLocations(RpcController, RegistryProtos.GetMetaRegionLocationsRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getMetaRegionMovePlan() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- getMetaRegionSet() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getMetaRegionState(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta server ZNode.
- getMetaRegionState(ZKWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta region server ZNode.
- getMetaReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaReplicaIdFromPath(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Parses the meta replicaId from the passed path.
- getMetaReplicaIdFromZNode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Parse the meta replicaId from the passed znode
- getMetaReplicaNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the znodes corresponding to the meta replicas from ZK
- getMetaReplicaNodesAndWatchChildren() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- getMetaScan(AsyncTable<?>, int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getMetaScan(Configuration, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getMetaScannerCaching() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMetaScanTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaScanTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getMetaTable() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getMetaWALProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getMetaWriter() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter meta data.
- getMeter() - Method in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
-
- getMeter() - Method in interface org.apache.hadoop.hbase.metrics.Timer
-
- getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getMethod() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The service method.
- getMethod() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getMethod(String, Class<?>...) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
-
- getMethod() - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Returns the method.
- getMethod() - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
- getMethodDescriptor(String, Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getMethodName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMethodName(CallRunner) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Return the Descriptors.MethodDescriptor#getName()
from callRunner
or "Unknown".
- getMetric(String, ConcurrentMap<String, T>, MetricsConnection.NewMetric<T>) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Get a metric for key
from map
, or create it with factory
.
- getMetricRegistries() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- getMetricRegistries() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns MetricRegistry's created.
- getMetricRegistry() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- getMetricRegistryForMaster() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the master level.
- getMetricRegistryForMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryForRegionServer() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
Returns a MetricRegistry that can be used to track metrics at the region server level.
- getMetricRegistryForRegionServer() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getMetricRegistryForRegionServer() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- getMetricRegistryForRegionServer() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost.WALEnvironment
-
- getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
- getMetricRegistryInfo() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- getMetricRegistryInfo() - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Return the MetricRegistryInfo object for this registry.
- getMetricRegistryInfos() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- getMetricRegistryInfos() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Returns MetricRegistryInfo's for the MetricRegistry's created.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- getMetrics() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter.MetricsSourceAdapter
-
- getMetrics() - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- getMetrics() - Method in interface org.apache.hadoop.hbase.metrics.MetricSet
-
A map of metric names to metrics.
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the metrics tracker for the region server
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Get the metrics instance.
- getMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- getMetrics() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getMetrics() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- getMetricsContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the metrics context.
- getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the metrics context.
- getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getMetricsContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getMetricsDescription() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the description of what this source exposes.
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the description of what this source exposes.
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getMetricsJmxContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the context in JMX that this source will be exposed through.
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the name of the context in JMX that this source will be exposed through.
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
Get all of the values since the last time this function was called.
- getMetricsMap(boolean) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
Get all of the values.
- getMetricsName() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the metrics that are being exported by this source.
- getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Get the name of the metrics that are being exported by this source.
- getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getMetricsName() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- getMetricsProcSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- getMetricsQuotaSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- getMetricsRegistry() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.io.MetricsIO
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- getMetricsUserAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getMetricsUserAggregate(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
-
- getMidKeyMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Used when writing the root block index of a multi-level block index.
- getMidpoint(CellComparator, Cell, Cell) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Try to return a Cell that falls between left
and right
but that is
shorter; i.e.
- getMidStripeSplitRatio(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getMillisFromLastRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getMillisToNextPeriodicRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMin() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Returns the smallest timestamp that should be considered
- getMin() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- getMin() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getMin() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- getMin() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Returns the lowest value in the snapshot.
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Returns the minimumTimestamp
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- getMin() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns the min column range for the filter
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns true if min column is inclusive, false otherwise
- getMinCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns lower bound below which compaction is selected without ratio test
- getMinFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMinFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns upper bound on number of files to be included in minor compactions
- getMinimumMidpointArray(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Try to get a byte array that falls between left and right as short as possible with
lexicographical order;
- getMinimumMidpointArray(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Try to create a new byte array that falls between left and right as short as possible with
lexicographical order.
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getMinimumTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the min timestamp of all the cells in the store file.
- getMinIndexNumEntries(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMinLoad() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getMinLocalityToForceCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinModifiedProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- getMinorCompactionCompressionType() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Compression type setting for minor compactions.
- getMinorCompactionCompressionType() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMinorCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the minor version of this HFile format
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getMinSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getMinSkew(double, double) - Static method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
Return the min skew of distribution
- getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Min age of store files hosted on this region server
- getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Min age of store files under this region
- getMinStoreFileAge() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMinStoreFileAge(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Min age of store files for this table
- getMinStoreFileAge(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMinStoreFileAge() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Min age of store files in this store
- getMinToStart() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Calculate min necessary to start.
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getMinVersions() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns The minimum number of versions to keep.
- getMinVersions() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getMinVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- getMinWidth(HttpServletRequest) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMissCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Gets the count of misses to the mob file cache.
- getMissedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of missing log files
- getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of missing store files
- getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMixedRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMixedRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of row reads on memstore and file per store
- getMixedRowReadsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMixedRowReadsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns number of row reads from file and memstore per store for this table
- getMixedRowReadsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getMixedRowReadsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the number of read requests from the files under this store.
- getMobColumnFamilies(TableDescriptor) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Get list of Mob column families (if any exists)
- getMobCompactionState(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Gets the mob file compaction state for a specific table.
- getMobCompactPartitionPolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get the mob compact partition policy for this family n
- getMobCompactPartitionPolicy() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMobCompactPartitionPolicy() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMobDataDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getMobDataNsDir(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getMobDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getMobFamilyPath(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the family dir of the mob files.
- getMobFamilyPath(Path, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the family dir of the mob files.
- getMobFileCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMobFileCache() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
May be null if this is a master which not carry table.
- getMobFileCache() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns The cache for mob files.
- getMobFileCacheAccessCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of accesses to the mob file cache.
- getMobFileCacheAccessCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFileCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of cached mob files.
- getMobFileCacheCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFileCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of items evicted from the mob file cache.
- getMobFileCacheEvictedCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFileCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the hit percent to the mob file cache.
- getMobFileCacheHitPercent() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFileCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the count of misses to the mob file cache.
- getMobFileCacheMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFileName(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the mob file name from the mob ref cell.
- getMobFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns number of mob files checked in the last HfileCorruptionChecker run
- getMobFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getMobFlushCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of the flushes in mob-enabled stores.
- getMobFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getMobFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of mob cells flushed to disk.
- getMobFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getMobFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of mob cells flushed to disk, in bytes.
- getMobFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobHome(Configuration) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the root dir of the mob files.
- getMobHome(Path) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the root dir of the mob files under the qualified HBase root dir.
- getMobPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the path of the mob hfiles.
- getMobRegionInfo(TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the RegionInfo of the mob files.
- getMobRegionPath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the region dir of the mob files.
- getMobRegionPath(Path, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the region dir of the mob files under the specified root dir.
- getMobScanCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getMobScanCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the number of scanned mob cells.
- getMobScanCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobScanCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getMobScanCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Gets the total amount of scanned mob cells, in bytes.
- getMobScanCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getMobStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the percentage of the mob store files
- getMobStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files in the mob dir
- getMobStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files in the mob store
- getMobTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the table dir of the mob files under the qualified HBase root dir.
- getMobTableDir(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getMobThreshold() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets the mob threshold of the family.
- getMobThreshold() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getMobThreshold() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getMobValueLength(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the mob value length from the mob ref cell.
- getModificationTime() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns Get the modification time of the file.
- getModificationTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getModificationTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getModificationTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
- getModificationTimestamp() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Get the modification time of this store file.
- getModifiedMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- getModifiedMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- getModTime() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getMonitor() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Returns the tracker for which tables should be archived.
- getMonitorStatus() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Set up monitor status if it is not created.
- getMonitorStatus() - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Set up monitor status if it is not created.
- getMostLocalEntityForRegion(int) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
- getMostRecentPosition() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Returns index of most recent
- getMovedRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMoveMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getMoveMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getMoveProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for move procedure
- getMovesCalculated() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
- getMovesExecuted() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
The number of moves actually executed by the balancer if it ran.
- getMTime() - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Last modification logical time n
- getMulti() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- getMultiFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMultiGetsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMultiMutationsCount() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getMultipleRowResource(String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getMultiplexer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getMultiplier() - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- getMultiServiceCalls() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getMutation(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- getMutation(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- getMutation(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Returns An unmodifiable list of the current mutations.
- getMutationsForCoprocs() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
This method is potentially expensive and useful mostly for non-replay CP path.
- getMutationsForCoprocs() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- getMutationsForCoprocs() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- getMutationsFromWALEntry(AdminProtos.WALEntry, CellScanner, Pair<WALKey, WALEdit>, Durability) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
This function is used to construct mutations from a WALEntry.
- getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMvcc() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- getMvcc() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getMvccFromOperationContext(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Return the write point of the previous succeed operation.
- getMvccReadPoint() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getMvccReadPoint(Scan) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
-
- getMvccReadPoint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the mvcc read point used to open a scanner.
- getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMvccReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- getMyAddress() - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- getMyEphemeralNodeFileName() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Get the name of the file used to store the znode contents
- getMyEphemeralNodePath() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getName() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
Returns the name of the file (not the full fs path, just the individual file name)
- getName() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- getName() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileableStoreFile
-
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Gets the fully qualified table name instance of the table that this
AsyncBufferedMutator
writes to.
- getName() - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getName() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the fully qualified table name instance of the table whose region we want to locate.
- getName() - Method in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
- getName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getName() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns a copy of Name of this column family
- getName() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getName() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getName() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the fully qualified table name instance of this table.
- getName() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- getName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getName() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getName() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
Returns the executor name inferred from the type and the servername on which this is running.
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Returns Name of this column family
- getName() - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.User
-
- getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return this Cipher's name
- getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the provider's name
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Returns this reader's "name".
- getName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getName() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getName() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getName() - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
Gets the name of the namespace.
- getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getName() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.SnapshotWithSize
-
- getName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.EagerMemStoreCompactionStrategy
-
- getName() - Method in exception org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
-
Returns name of lease
- getName() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- getName() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
Human readable name of the processor
- getName() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Returns the column name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the region server's name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the region name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Returns the table name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
Returns the name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Returns the region name
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Returns the table name
- getName() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
Returns the table name
- getName() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get group name.
- getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getName() - Method in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- getName() - Method in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
Returns the unique name to identify this authentication method among other HBase auth methods.
- getName() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.TableName
-
- getName() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getName() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
returns the name of this checksum type
- getName() - Method in enum org.apache.hadoop.hbase.util.DNS.ServerType
-
- getName() - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Name of this column family
- getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Returns The name string of this column family
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Get the name of the table as a String
- getNameAsString() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name as a string
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the user name as a string
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.NamedQueuePayload
-
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- getNamedQueueEvent() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- getNamedQueueRecorder() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
get NamedQueue Provider to add different logs to ringbuffer n
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.LogEventHandler
-
Retrieve in memory queue records from ringbuffer
- getNamedQueueRecords(NamedQueueGetRequest) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
Retrieve in memory queue records from ringbuffer
- getNamedQueueRecords(NamedQueueGetRequest) - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Retrieve in memory queue records from ringbuffer
- getNameForThrottling(HStore, String) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.ThroughputControlUtil
-
Generate a name for throttling, to prevent name conflict when multiple IO operation running
parallel on the same store.
- getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns name converted to bytes.
- getNamespace() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- getNamespace(String) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Get a Namespace
- getNamespace(String) - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- getNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get a Namespace
- getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getNamespace() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the namespace this table is in.
- getNamespace() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNamespace() - Method in class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getNamespace() - Method in class org.apache.hadoop.hbase.security.access.NamespacePermission
-
- getNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getNamespace() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a namespace descriptor by name.
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a namespace descriptor by name
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getNamespaceDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the Path
object representing the namespace directory under
path rootdir
- getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the Namespace filter regex
- getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Dispatch to NamespaceInstanceResource for getting list of tables.
- getNamespaceInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.NamespacesResource
-
Dispatch to NamespaceInstanceResource
- getNamespaceLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified namespace.
- getNamespaceLock(String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getNamespaceName() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
-
Returns the namespace name
- getNamespaceName() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- getNamespaceName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getNamespaceName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getNamespaceName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getNamespaceName() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
- getNamespacePermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- getNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceQuotaCache() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- getNamespaceQuotaManager() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- getNamespaceQuotaSnapshot(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- getNamespaceQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Returns an unmodifiable view over the current
SpaceQuotaSnapshot
objects for each HBase
namespace with a quota defined.
- getNamespaceQuotaTables() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Returns an unmodifiable view of all tables in namespaces that have namespace quotas.
- getNamespaceResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getNamespaceRootPaths(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
return paths that user will namespace permission will visit
- getNamespaceRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaces() - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Get all Namespaces
- getNamespaces() - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- getNamespaces() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get all Namespaces
- getNamespaces() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable namespace set of this peer
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getNamespaces() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get replicable namespace set of this peer
- getNamespaces() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
-
Returns all namespaces
- getNamespaceSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a set of the names of all namespaces containing snapshot entries.
- getNamespaceSnapshotSize(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Fetches the computed size of all snapshots against tables in a namespace for space quotas.
- getNamespaceSnapshotStore() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- getNamespaceSpaceUtilization() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Gets the space usage and limit for each namespace.
- getNamespaceSpaceUtilization() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNamespacesWithQuotas() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
- getNamespaceTable() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getNamespaceTableCfWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking replication per table and CF.
- getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
-
Ideally, getNameAsString should contain namespace within it, but if the namespace is default,
it just returns the name.
- getNbEntries() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- getNbHFiles() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the number of HFiles in this batch
- getNbOperations() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns total number of operations in this batch
- getNbRowKeys() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the number of distinct row keys in this batch
- getNeedResults() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getNegativeResultsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for bloom negative results count
- getNegotiatedProperty(String) - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- getNegotiatedQop() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- getNegotiatedQop() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getNettyDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
Returns the current amount of direct memory used by netty module.
- getNettyDmUsage() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getNettyDmUsage() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNewAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- getNewExternalChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- getNewExternalChunk(int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- getNewExternalChunk(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getNewExternalChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getNewMultiActionRunnable(ServerName, MultiAction, int) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getNewPath() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
retrieve the next path to use for writing.
- getNewPeerConfig() - Method in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- getNewPeerConfig() - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- getNewPeerConfig() - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- getNewRpcRetryingCallerFactory(Configuration) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns a new RpcRetryingCallerFactory from the given Configuration
.
- getNewRpcRetryingCallerFactory(Configuration) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getNextBlockOnDiskSize(boolean, ByteBuff, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- getNextBlockOnDiskSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getNextCallSeq() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are not sure which key must be next seeked to, can inherit this implementation
that, by default, returns a null Cell.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Pick the next cell that the scanner should seek to.
- getNextDelay(int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getNextForFuzzyRule(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextForFuzzyRule(boolean, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextForFuzzyRule(boolean, byte[], int, int, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextFreeOffset() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns the next key in the index (the key to seek to the next block)
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- getNextLogLine(WAL.Reader, Path, boolean) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getNextMajorCompactTime(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
n * @return When to run next major compaction
- getNextMode() - Method in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
-
- getNextPriority(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
- getNextQueue(CallRunner) - Method in interface org.apache.hadoop.hbase.ipc.QueueBalancer
-
Returns the index of the next queue to which a request should be inserted
- getNextQueue(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RandomQueueBalancer
-
- getNextRangeIndex(byte[]) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
Calculates the position where the given rowkey fits in the ranges list.
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getNextRegionForUnload() - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
-
- getNextRow(Cell, NavigableSet<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getNextRowOrNextColumn(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Retrieve the MatchCode for the next row or column n
- getNextRowOrNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- getNextRowOrNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- getNextRowOrNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- getNextSequenceId(WAL) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Method to safely get the next sequence number.
- getNextSleepInterval(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Get how long the caller should sleep according to the current size and current cycle's total
push size and start tick, return the sleep interval for throttling control.
- getNNAddresses(DistributedFileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns A set containing all namenode addresses of fs
- getNoChecksumFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the filesystem that is specially setup for doing reads from storage.
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the name of the current node from the specified fully-qualified path.
- getNonce() - Method in class org.apache.hadoop.hbase.client.Action
-
- getNonce() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getNonce() - Method in class org.apache.hadoop.hbase.client.NoncedRegionServerCallable
-
- getNonce(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- getNonce(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- getNonce(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- getNonce() - Method in class org.apache.hadoop.hbase.util.NonceKey
-
- getNonce() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns The nonce
- getNonce() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns The nonce
- getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns Nonce generator for this ClusterConnection; may be null if disabled in configuration.
- getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.NoncedRegionServerCallable
-
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
-
Returns the nonce group (client ID) of this client manager.
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- getNonceGroup(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- getNonceGroup(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- getNonceGroup(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.util.NonceKey
-
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns The nonce group
- getNonceGroup() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns The nonce group
- getNonceKey() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- getNonceKey() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getNonceManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNonceManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Only required for "old" log replay; if it's removed, remove this.
- getNoneCompressor() - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getNoneUncompressor() - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getNonFavoredAssignedRegions() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return the regions not assigned to its favored nodes
- getNonMetaRegionLocator() - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getNonMetaRegionsMovePlan() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- getNonRootIndexedKey(ByteBuff, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
The indexed key at the ith position in the nonRootIndex.
- getNonRootSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Returns the size of this chunk if stored in the non-root index block format
- getNonSharedArchivedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getNoopLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
Returns the singleton latch which does nothing.
- getNormalizationTargets() - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
-
- getNormalizerTargetRegionCount() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionCount() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if there is the target region count.
- getNormalizerTargetRegionCount() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getNormalizerTargetRegionSize() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if there is the target region size.
- getNormalizerTargetRegionSize() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if there is the target region size.
- getNormalizerTargetRegionSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getNoSuchSnapshot() - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns a singleton that corresponds to no snapshot information.
- getNotifierForTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNullPollCalls() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- getNumActionsPerServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getNumAlwaysStandByMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumAtOrBelow(long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- getNumAtOrBelow(long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getNumberOfActionsInProgress() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getNumberOfCachedRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getNumberOfCachedRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Return the number of cached region for a table.
- getNumberOfChildren(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the number of children of the specified node.
- getNumberOfChoresMissingStartTime() - Method in class org.apache.hadoop.hbase.ChoreService
-
Return number of chores that this service currently has scheduled that are missing their
scheduled start time
- getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Returns The number of currently registered listeners
- getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
Returns number of regions we've recovered
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRulesLoaded() - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
- getNumberOfRunningProcess() - Method in class org.apache.hadoop.hbase.util.JVM
-
Workaround to get the current number of process running.
- getNumberOfScheduledChores() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns number of chores that this service currently has scheduled
- getNumberOfStatistics() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Returns number of statistics
- getNumberOfTasksInProgress() - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Returns The number of running task.
- getNumberOfTasksInProgress() - Method in class org.apache.hadoop.hbase.client.SimpleRequestController
-
- getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
The number of threads in the thread pool that will run the map function.
- getNumBytesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumBytesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumChunks() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- getNumCompactionsCompleted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumCompactionsCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumCompactionsFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of compactions that have been reported as failed on this region.
- getNumCompactionsFailed() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumCompactionsQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of compactions that are currently queued(or being executed) at point
in time
- getNumCompactionsQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getNumDataNodes() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of dead region servers
- getNumDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumDrainingRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of draining region servers
- getNumDrainingRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Returns the number of entries in this block index chunk
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getNumFilesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumFilesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumFlushesQueued() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the total number of flushes currently queued(being executed) for this region at point
in time
- getNumFlushesQueued() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getNumGeneralCallsDropped() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
If CoDel-based RPC executors are used, retrieves the number of Calls that were dropped from
general queue because RPC executor is under high load; returns 0 otherwise.
- getNumGeneralCallsDropped() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getNumHFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getNumHFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Number of HFiles in this store
- getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Returns the number of levels in this block index.
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getNumLifoModeSwitches() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
If CoDel-based RPC executors are used, retrieves the number of Calls that were picked from the
tail of the queue (indicating adaptive LIFO mode, when in the period of overloade we serve last
requests first); returns 0 otherwise.
- getNumLifoModeSwitches() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the number of log files in use
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta, count the
number of files (rolled and active).
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- getNumLogFiles() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Get number of the log files this provider is managing
- getNumMasters() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of mutations received with WAL explicitly turned off.
- getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns the number of mutations processed bypassing the WAL
- getNumObservers() - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Returns the number of observers.
- getNumOfAppends() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getNumOfCells() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- getNumOfChunksReturnedToPool(Set<Integer>) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getNumOfDeletedLargeFiles() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getNumOfDeletedSmallFiles() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getNumOfDeletes() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getNumOfIncrements() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getNumOfPuts() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getNumOfReplicas - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- getNumOfSegments() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- getNumOnlineRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
The number of online regions
- getNumOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumOpenConnections() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
The number of open RPC conections
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
The number of open RPC conections
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
Returns the number of currently opened writers
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- getNumOpenWriters() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Get current open writers
- getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- getNumQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
Returns number of queues.
- getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of reference files on this region server
- getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns Number of reference files under this region
- getNumReferenceFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumReferenceFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns Number of reference files for this table
- getNumReferenceFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getNumReferenceFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Number of reference files in this store
- getNumRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- getNumRegions() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getNumRegions(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Computes the total number of regions in a table.
- getNumRegions(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of regions hosted on for this table
- getNumRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getNumRegions() - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- getNumRegionsAdded() - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
-
- getNumRegionsComparator() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- getNumRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of live region servers
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getNumRegionsOnFavoredNodeByPosition(FavoredNodesPlan.Position) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return the number of regions based on the position (primary/secondary/ tertiary) assigned to
their favored nodes n * @return the number of regions
- getNumRegionsOpened() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getNumRegisteredProviders() - Method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Returns the number of providers that have been registered.
- getNumRegisteredProviders() - Method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Returns the number of registered providers.
- getNumReportedRegions(TableName, QuotaSnapshotStore<TableName>) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Computes the number of regions reported for a table.
- getNumRolledLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Returns the number of rolled log files
- getNumRolledLogFiles(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
returns the number of rolled WAL files.
- getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Returns how many block index entries there are in the root level
- getNumServers() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getNumSinks() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumStoreFiles(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of store files hosted for this table
- getNumStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumStores(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of stores hosted on for this table
- getNumStores(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- getNumThreads() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Returns the number of threads/slots passed to start()
- getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getNumUniqueKeys() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- getNumUniqueKeys() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getNumWALFiles() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of master WAL files.
- getNumWALFiles() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumWALFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of WAL files of this region server.
- getNumWALFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumWALSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of WAL files with slow appends for this region server.
- getNumWALSlowAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getNumZkServers() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getObject() - Method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedContainer
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Initialize the model from a protobuf representation.
- getObservedSnapshotSizes(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Fetches any persisted HBase snapshot sizes stored in the quota table.
- getOffHeapMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the off heap memstore.
- getOffHeapMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getOffHeapMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the off heap memstore on this region server.
- getOffHeapMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- getOffHeapSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getOffHeapSize() - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- getOffPeakHours() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getOffPeakMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getOffset() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Return the offset into the buffer.
- getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getOffset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Returns the offset
- getOffset() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The offset, the index into the underlying byte[] at which this range begins.
- getOffset() - Method in class org.apache.hadoop.hbase.util.Bytes
-
Return the offset into the buffer.
- getOldestHfileTs(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOldestHfileTs(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This can be used to determine the last time all files of this region were major compacted.
- getOldestRITTime() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getOldestSeqIdOfStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOldestToCompact(long, long) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- getOldestWalAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getOldestWalAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getOldestWalAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getOldestWalAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getOldestWalAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- getOldestWalTimestamp() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- getOldLocality(ServerName, byte[], Map<ServerName, ServerMetrics>) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- getOldLogDir() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Get the directory where old logs go
- getOldLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are archived
- getOldPath() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getOldPeerConfig() - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- getOldPeerConfig() - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- getOldSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the recovered sources of this rs
- getOnDiskDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
- getOnDiskDataSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the size of data on disk + header.
- getOnDiskSizeWithHeader(ByteBuff, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Parse total on disk size including header and checksum.
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the on-disk size of header + data part + checksum.
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Returns the on-disk size of the block.
- getOnDiskSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the on-disk size of the data part + checksum (header excluded).
- getOnDiskSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Returns the on-disk size of the data portion of the block.
- getOneMinuteRate() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- getOneMinuteRate() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Returns the one-minute exponentially-weighted moving average rate at which events have occurred
since the meter was created.
- getOneRandomRack(Set<String>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getOneRandomServer(String, Set<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Gets a random server from the specified rack and skips anything specified.
- getOneRandomServer(String) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getOnHeapCacheSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- getOnheapGlobalMemStoreSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Returns the onheap global memstore limit based on the config
'hbase.regionserver.global.memstore.size'.
- getOnHeapMemStoreLimit() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the limit size of the on heap memstore.
- getOnHeapMemStoreLimit() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getOnHeapMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the on heap memstore on this region server.
- getOnHeapMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getOnlineEntries() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getOnlineFavoredNodes(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getOnlineRegionInfos(List<? extends Region>) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getOnlineRegions() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getOnlineRegions() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getOnlineRegionsAsPrintableString() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegionsInterface(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side
OnlineRegions
interface for the specific region server.
- getOnlineRegionsInterface(ServerName) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getOnlineRegionsLocalContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For tests, web ui and metrics.
- getOnlineRS() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getOnlineServers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getOnlineServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns Read-only map of servers to serverinfo
- getOnlineServers(MasterServices) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getOnlineServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns A copy of the internal list of online servers.
- getOnlineServersListWithPredicator(List<ServerName>, Predicate<ServerMetrics>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getOnlineTables() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online tables in this RS.
- getOpenAndCloseThreadPool(int, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOpenFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of opened filed descriptor for the runtime jvm.
- getOpenMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getOpenMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getOpenProcId() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getOpenProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for OpenRegionProcedure
- getOpenRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the latest sequence number that was read from storage when this region was opened
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getOpenSeqNumForParentRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getOperation - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ReplicationFuture
-
- getOperation - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ReplicationProcedureBiConsumer
-
- getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
n * @return The operation(Mutation) at the specified position.
- getOperationId() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getOperationId() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- getOperationsFromCoprocessors(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
n * @return Gets the status code for the operation(Mutation) at the specified position.
- getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
n
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the operation timeout for a rpc call.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each operation in Table instance.
- getOperationTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getOperationTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- getOperationTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getOperationTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each operation in Table instance.
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getOperationTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getOperationTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.AddColumnFamilyFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.CreateTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.DeleteColumnFamilyFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.DeleteTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.DisableTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.EnableTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.MergeTableRegionsFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyColumnFamilyFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyColumnFamilyStoreFileTrackerFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTablerStoreFileTrackerFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.NamespaceFuture
-
Returns the operation type like CREATE_NAMESPACE, DELETE_NAMESPACE, etc.
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.RestoreSnapshotFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.SplitTableRegionFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
Returns the operation type like CREATE, DELETE, DISABLE etc.
- getOperationType() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TruncateTableFuture
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.AddColumnFamilyProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.CreateNamespaceProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.CreateTableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.DeleteColumnFamilyProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.DeleteNamespaceProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.DeleteTableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.DisableTableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.EnableTableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.MergeTableRegionProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyColumnFamilyProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyColumnFamilyStoreFileTrackerProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyNamespaceProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyTableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyTableStoreFileTrackerProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.NamespaceProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.SplitTableRegionProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.TableProcedureBiConsumer
-
- getOperationType() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.TruncateTableProcedureBiConsumer
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
Returns the bitwise operator
- getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
Deprecated.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the operator.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Deprecated.
- getOperator(String) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- getOperator() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getOperator(byte) - Static method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- getOpsShipped() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Gets the number of OPs shipped by this source queue to target cluster.
- getOPsShipped() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getOption() - Method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- getOptionAsDouble(CommandLine, String, double) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getOptionAsInt(CommandLine, String, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getOptionAsInt(CommandLine, String, int, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getOptionAsLong(CommandLine, String, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getOptionAsLong(CommandLine, String, int, int) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getOptions() - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
-
- getOptions() - Method in class org.apache.hadoop.hbase.hbtop.HBTop
-
- getOptions() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
-
- getOptions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- getOrComputeLocality(int, int, BalancerClusterState.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Looks up locality from cache of localities.
- getOrComputeRackLocalities() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Retrieves and lazily initializes a field storing the locality of every region/server
combination
- getOrComputeRegionsToMostLocalEntities(BalancerClusterState.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Lazily initializes and retrieves a mapping of region -> server for which region has the highest
the locality
- getOrComputeWeightedLocality(int, int, BalancerClusterState.LocalityType) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Returns locality weighted by region size in MB.
- getOrCreate(K, PoolMap.PoolResourceSupplier<V>) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- getOrCreate(PoolMap.PoolResourceSupplier<R>) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- getOrCreate(PoolMap.PoolResourceSupplier<R>) - Method in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- getOrCreate(PoolMap.PoolResourceSupplier<R>) - Method in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- getOrCreateFamilies() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- getOrCreateInfo(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Gets the entry in regionInfo corresponding to the the given encoded region name.
- getOrCreateLowestSequenceIds(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- getOrCreateMetricsClient(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
Create a instance of ClientMetrics if not present otherwise return the previous one
- getOrCreateMetricsClient(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- getOrCreateMetricsUser(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- getOrCreateMetricsUser(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
Returns a MetricsUserSource if already exists, or creates and registers one for this user
- getOrCreateMetricsUser(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- getOrCreateNode(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- getOrCreateRegionStateNode(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getOrCreateServer(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Be judicious calling this method.
- getOrCreateTableHistogram(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
-
- getOrCreateTableMeter(TableName) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
-
- getOrCreateTableSource(String, MetricsTableWrapperAggregate) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
Returns MetricsTableSource registered for the table.
- getOrCreateTableSource(String, MetricsTableWrapperAggregate) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
-
- getOrDefault(Bytes, Function<byte[], T>, T) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getOrDefault(Bytes, Function<String, T>, T) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getOrDefault(String, Function<String, T>, T) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Retrieve the sort
Order
imposed by this data type, or null when natural ordering is not
preserved.
- getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
-
- getOrderOfSize() - Method in enum org.apache.hadoop.hbase.Size.Unit
-
- getOrEmptyString(Configuration, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Extracts the value for the given key from the configuration of returns a string of zero length.
- getOrFetch(AtomicReference<T>, AtomicReference<CompletableFuture<T>>, boolean, Supplier<CompletableFuture<T>>, Predicate<T>, String) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
-
- getOriginatingClusterId() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
- getOriginatingClusterId() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
Returns the origin path of the hfile.
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- getOrigLogSeqNum() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Return a positive long if current WALKeyImpl is created from a replay edit; a replay edit is an
edit that came in when replaying WALs of a crashed server.
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Return a positive long if current WALKeyImpl is created from a replay edit; a replay edit is an
edit that came in when replaying WALs of a crashed server.
- getOrMakeChunk() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Get the current chunk, or, if there is no current chunk, allocate a new one from the JVM.
- getOrphanRegionsOnFS() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
The regions have directory on FileSystem, but no region info in meta.
- getOrphanRegionsOnRS() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
The regions only opened on RegionServers, but no region info in meta.
- getOSVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
Returns the OS name, version, and hardware architecture
- getOuputStream() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- getOutput(HttpServletRequest) - Method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- getOutput() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Returns the output committer.
- getOutputCounts() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
Returns a map from encoded region ID to the number of edits written out for that region.
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- getOutputFileSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- getOutputFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Returns the total file size for flush output files, in bytes
- getOutputPath(SnapshotProtos.SnapshotFileInfo) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
Returns the location where the inputPath will be copied.
- getOutputStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Currently, we need to expose the writer's OutputStream to tests so that they can manipulate the
default behavior (such as setting the maxRecoveryErrorCount value).
- getOutputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getOutputStream() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- getOutputStreamForCellEncoder() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getOverhead() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- getOverhead() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getOverlaps() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getOwner() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getOwnerString() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getOwnerString() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getPageEndPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getPageSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- getPageStartPosition() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- getParam() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getParam() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The call parameter message.
- getParam() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getParam() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- getParameter(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Unquote the name and quote the value.
- getParameterMap() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- getParameterNames() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Return the set of parameter names, quoting each name.
- getParameterTypes(Object[]) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- getParameterValues(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- getParams() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
-
- getParams() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getParent(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the full path of the immediate parent of the specified node.
- getParentProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getParentRegion() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getParentRegionNames() - Method in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- getParentRegionServerName(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getParentsBytes(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getParentToChildrenPairMap() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the map of parent-children_pair.
- getParsedServers() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- getParserForTypeMethod - Static variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Gets the partition number for a given key (hence record) given the total number of partitions
i.e.
- getPartition(Import.CellWritableComparable, Cell, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
-
- getPartition(Import.KeyValueWritableComparable, KeyValue, int) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparablePartitioner
-
Deprecated.
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getPartitionSize(float) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getPassword(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the password from the Configuration instance using the getPassword method if it exists.
- getPassword(TokenIdentifier) - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider.SaslDigestCallbackHandler
-
- getPath() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
Returns the path to this file
- getPath() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- getPath() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileableStoreFile
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Returns the path to this
HFile
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Returns Path or null if we were passed a stream rather than a Path.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets the mob file path.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- getPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Path or null if this StoreFile was made with a Stream.
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns The Path
of the file
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- getPath(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return the 'path' component of a Path.
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns path to znode where the ZKOp will occur
- getPathHelper() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- GetPathName() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetPathName
-
- getPathOffsetEndStr(Path, long, long) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePreadReader
-
- getPathsToWatch() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
Returns the zk path(s) to watch
- getPathsToWatch() - Method in class org.apache.hadoop.hbase.master.zksyncer.MasterAddressSyncer
-
- getPathsToWatch() - Method in class org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer
-
- getPattern(String, Pattern) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getPattern() - Method in interface org.apache.hadoop.hbase.filter.RegexStringComparator.Engine
-
Returns the string representation of the configured regular expression for matching
- getPattern() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- getPattern() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- getPauseMillis() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getPauseMillisForServerOverloaded() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getPauseNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getPauseNsForServerOverloaded() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPauseTime(int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getPayload() - Method in class org.apache.hadoop.hbase.namequeues.RingBufferEnvelope
-
Retrieve current namedQueue payload
NamedQueuePayload
available on Envelope and free up
the Envelope
- getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the ReplicationPeerImpl for the specified cached peer.
- getPeerBandwidth() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the per node bandwidth upper limit for this peer
- getPeerBandwidth() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- getPeerCache() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- getPeerClusterConfiguration(Configuration, ReplicationPeerDescription) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Returns the configuration needed to talk to the remote slave cluster.
- getPeerClusterConfiguration(ReplicationPeerConfig, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the peer config object
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get the peer config object
- getPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Get the peer config of a replication peer.
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerId(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getPeerId() - Method in interface org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface
-
- getPeerId() - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- getPeerId() - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the slave peer ID n
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to.
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getPeerLock(String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getPeerNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- getPeerOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.DisablePeerProcedure
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.EnablePeerProcedure
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- getPeerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- getPeerProcedureHandler() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns a Handler to handle peer procedures.
- getPeerProcedureHandler() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- getPeerQueue(String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getPeerQuorumConfig(Configuration, String) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Returns the state of the peer by reading local cache.
- getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- getPeerStateNode(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- getPeerStorage() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- getPeerUUID() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a UUID of the provided peer id.
- getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- getPeerUUID() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- getPercentFileLocal() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local.
- getPercentFileLocal() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getPercentFileLocalSecondaryRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local for secondary region replicas.
- getPercentFileLocalSecondaryRegions() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getPeriod(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Extracts the period for the chore from the configuration.
- getPeriod(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Extracts the period for the chore from the configuration.
- getPeriod(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
Extracts the period for the chore from the configuration.
- getPeriod(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Extracts the period for the chore from the configuration.
- getPeriod(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Extracts the period for the chore from the configuration.
- getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns period to execute chore in getTimeUnit() units
- getPeriod() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Returns the sleep period in milliseconds
- getPeriodicalFlushTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the periodical flush interval, 0 means disabled.
- getPeriodicalFlushTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- getPermission() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- getPermissions(Configuration, byte[], Table, byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Reads user permission assignments stored in the l:
column family of the first
table row in _acl_
.
- getPerServerFailuresCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getPerTableFailuresCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getPid() - Static method in class org.apache.hadoop.hbase.client.ClientIdGenerator
-
Returns PID of the current process, if it can be extracted from JVM name, or null.
- getPid() - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
-
- getPipeline() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Return current pipeline.
- getPipeline() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- getPipeline() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- getPipeline() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This method gets the pipeline for the current WAL.
- getPipeline() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- getPipeline() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This method gets the pipeline for the current WAL.
- getPipelineSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getPluggableQueueClass() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getPolicies() - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- getPolicy() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns the violation policy, which may be null.
- getPolicy() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns the violation policy, which may not be presented.
- getPolicyEnforcement(Region) - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- getPolicyEnforcement(TableName) - Method in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
-
- getPolicyName() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
-
- getPolicyName() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
- getPollCalls() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- getPool() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getPool() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getPool() - Method in class org.apache.hadoop.hbase.client.HTable
-
The pool is used for mutli requests for this HTable
- getPool() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getPoolAllocationBytes() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getPoolCompletedTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolCompletedTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPooledChunks() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getPoolLargestPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolLargestPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getPoolSize() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getPoolSize(ChunkCreator.ChunkType) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getPort() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns -1 if not set
- getPort() - Method in class org.apache.hadoop.hbase.net.Address
-
- getPort() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPort() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getPos() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- getPos() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
Returns the position of the last Entry returned by next()
- getPosition() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current position
marker.
- getPosition() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- getPreadMaxBytes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getPreadScanner(boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Get a scanner which uses pread.
- getPreallocatedEventCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- getPrefixLength() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getPrepareFlushResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getPreparePutToStoreMap() - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- getPrettyHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns pretty summary of hist
.
- getPrevBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the offset of the previous block of the same type in the file, or -1 if unknown
- getPrevCell() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- getPrevCell() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Returns the previous cell written by this writer
- getPrevious() - Method in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
-
- getPreviousNamespaceSnapshotSize(Table, String) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Fetches the current size of all snapshots in the given namespace
.
- getPrimaryCallTimeoutMicroSecond() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getPrimaryCallTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getPrimaryEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getPrimaryHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getPrimaryHRIForDeployedReplica() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getPrimaryMetaScanTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getPrimaryMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getPrimaryOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getPrimaryScanTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getPrimaryTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- getPrimaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- getPrincipalWithoutRealm(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getPriority() - Method in class org.apache.hadoop.hbase.client.Action
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
-
- getPriority(TableName) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- getPriority() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns The order to execute this coprocessor
- getPriority() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getPriority() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
- getPriority() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getPriority() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the priority assigned to the loaded coprocessor
- getPriority() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Get the priority level for this handler instance.
- getPriority() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- getPriority() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns The priority of this request
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the 'priority type' of the specified request.
- getPriority() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The Priority of this call.
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
Returns a 'priority' based on the request type.
- getPriority() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns priority of compaction request
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Gets the priority for the request
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriority(RPCProtos.RequestHeader, Message, User) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the priority queue for metrics.
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getProc() - Method in class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- getProcedure() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns the procedure.
- getProcedure() - Method in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- getProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProcedure(Class<T>, long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProcedure() - Method in class org.apache.hadoop.hbase.procedure2.store.ProtoAndProcedure
-
- getProcedureEnvironment() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getProcedureEvent() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- getProcedureManager(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- getProcedureManagers() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- getProcedureMetrics(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getProcedureMetrics(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Override this method to provide procedure specific counters for submitted count, failed count
and time histogram.
- getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns Return set of all procedure names.
- getProcedureResult(MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- getProcedureResult(long, CompletableFuture<Void>, int) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get procedures.
- getProcedures() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List procedures
- getProcedures() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getProcedures() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getProcedures() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getProcedures(RpcController, MasterProtos.GetProceduresRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getProcedures() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProcedures(RpcController, MasterProtos.GetProceduresRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getProcedures() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get procedures
- getProcedures() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Get procedures.
- getProcedures() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- getProcedures() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getProcedureScheduler() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getProcedureScheduler() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getProcedureScheduler() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
-
Return the unique signature of the procedure.
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- getProcedureStore() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProcedureTimeout - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getProcessingTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getProcessName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProcessName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getProcessPID() - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getProcessTime() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor.PacketAckData
-
- getProcExecutionLock() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProcId() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- getProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getProcIdHashCode(long) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Get an hashcode for the specified Procedure ID
- getProcIds() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getProcName() - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- getProcName() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getProcName() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getProcName() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getProcName() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- getProcName() - Method in class org.apache.hadoop.hbase.procedure2.FailedProcedure
-
- getProcName() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getProcStack(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Return the aggregate progress for all currently active compactions.
- getProgress() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- getProgressPct() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
getter for calculated percent complete n
- getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the promoted type from the proto message n * @return the promoted-type
instance from the PB message
- getProperties() - Method in interface org.apache.hadoop.hbase.client.CoprocessorDescriptor
-
Returns Arbitrary key-value parameter pairs passed into the coprocessor.
- getProperties() - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- getProperties() - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
Returns The map of uncategorized namespace properties.
- getPropertySources(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getProto() - Method in class org.apache.hadoop.hbase.procedure2.store.ProtoAndProcedure
-
- getProto() - Method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
Returns a copy of the internal state of this
- getProto() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
Returns a copy of the internal state of this
- getProtobuf(UriInfo, String) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
-
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- getProtocolFactory() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type n * @return the PB message for
the cell-type instance
- getProtoForPromotedType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForPromotedType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForPromotedType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the promoted type n * @return the PB message
for the promoted-type instance
- getProtoForType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoViolationPolicy(SpaceViolationPolicy) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getProvider(String, String, String) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
instantiate a provider from a config property.
- getProviderClass(String, String) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getProxyuserConfiguration(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
- getPushDownFilters() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getQop(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
- getQualifiedMobRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the qualified root dir of the mob files.
- getQualifiedPath() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getQualifiedPath() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns Returns the qualified path of this StoreFile
- getQualifiedStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
-
Initializes the staging directory and returns the qualified path.
- getQualifier() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the qualifier to check
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
Returns the qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Returns the column qualifier
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Returns the qualifier
- getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getQualifier() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getQualifierArray() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifierBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getQualifierByte(Cell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the column qualifier bytes.
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getQualifierByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierLength(int, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierLength(int, int, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of qualifier bytes.
- getQualifierLength() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier length
- getQualifierLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier length
- getQualifierLength(int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier length
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first qualifier byte
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier offset
- getQualifierOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier offset
- getQualifierOffset(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Qualifier offset
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where column qualifier bytes start
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierPosition(int, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColByteBufferExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowColByteBufferExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getQualifierPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getQualifierString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
Computes the quantiles give the ratios.
- getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
Computes the quantiles give the ratios.
- getQuantiles() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
- getQuantiles(double[]) - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- getQuantiles(double[]) - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Return the values with the given quantiles.
- getQuantiles() - Method in interface org.apache.hadoop.hbase.metrics.Snapshot
-
Return the values with the default quantiles.
- getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of successfully quarantined paths after checkTables is called.
- getQuarantinedMobFiles() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Returns the set of successfully quarantined paths after checkTables is called.
- getQueue() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getQueue(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- getQueue(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
Return queue for the given walGroupId Please don't add or remove elements from the returned
queue.
- getQueue(ServerName) - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getQueueId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the queue id that the source is replicating to
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getQueueId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the length of the pending queue
- getQueueNode(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RandomQueueBalancer
-
Exposed for use in tests
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the list of request queues
- getQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- getQueueSize(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
Get the queue size for the given walGroupId.
- getQueueSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getQueueStorage() - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- getQueueStorage() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getQueuesZNodeCversion() - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getQueueTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the quorum address of this instance.
- getQuorumString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
-
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
List the quotas based on the filter.
- getQuota(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getQuota(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getQuota(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getQuota(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
Returns the quota for an operation.
- getQuota(QuotaFilter) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getQuotaCache() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- getQuotaForNamespace(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
Fetches the namespace quota.
- getQuotaForTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
Fetches the table quota.
- getQuotaObserverChore() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getQuotas(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getQuotas(Connection, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getQuotaScope() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getQuotaSettings() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
-
Computes a list of QuotaSettings that present the complete quota state of the combination of
this user, table, and/or namespace.
- getQuotaSettings() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- getQuotaSnapshot() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- getQuotaSnapshot() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
- getQuotaState(ConcurrentHashMap<K, QuotaState>, K) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the QuotaState requested.
- getQuotaStates(RpcController, QuotaProtos.GetQuotaStatesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getQuotaStates(RpcController, QuotaProtos.GetQuotaStatesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getQuotaStatus() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the status of the quota.
- getQuotaStatus() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the status of the quota.
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
-
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory.QuotaGlobalsSettingsBypass
-
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getRack(ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState.DefaultRackManager
-
- getRack(ServerName) - Method in class org.apache.hadoop.hbase.master.RackManager
-
Get the name of the rack containing a server, according to the DNS to switch mapping.
- getRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.RackManager
-
- getRackForRegion(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Maps region index to rack index
- getRackManager() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getRackOfServer(ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry>, List<BucketCache.RAMQueueEntry>) - Static method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Blocks until elements available in q
then tries to grab as many as possible before
returning.
- getRandomGenerator() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
Returns any candidate generator in random
- getRandomGenerator() - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
Select the candidate generator to use based on the cost of cost functions.
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getRandomReplicaId() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
Select an random replica id (including the primary replica id).
- getRange(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
Returns the ranges to be counted
- getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- getRanges() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
Returns the type of range histogram size or time
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- getRateLimiter() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
Used in test only.
- getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- getRaw(String) - Method in interface org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfigMap
-
- getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- getRaw(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getReachedBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getReachedBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
execution and release on each subprocedure.
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Returns the number of bytes available to read to avoid exceeding the quota
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the number of bytes available to read to avoid exceeding the quota
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getReadBalancer() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Returns Reader that underlies this Scanner instance.
- getReader() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getReader() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getReader(FileStatus, boolean, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReader(Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReaderContext() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getReaderType() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- getReadFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getReadFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getReadFailures() - Method in interface org.apache.hadoop.hbase.tool.Canary
-
- getReadFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- getReadFailures() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getReadFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getReadLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getReadLatencyMap() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getReadLockCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadOnlyConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadOnlyConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getReadOnlyConfiguration() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getReadOnlyConfiguration() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
-
Returns the read point of the current scan
- getReadPoint(IsolationLevel) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns readpoint considering given IsolationLevel.
- getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- getReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getReadQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the read queue for metrics when use RWQueueRpcExecutor.
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getReadQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of read requests made to region
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of read requests that have been issued against this region
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getReadRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of read requests that have been issued against this table
- getReadRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of read requests made by user
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- getReadRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of read requests to regions hosted on this region server.
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns read requests count for this region
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the current total read requests made to region
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- getReadRequestsRatePerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the rate of read requests per second to regions hosted on this region server.
- getReadRequestsRatePerSecond() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getReadRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getReadRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- getReadRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getReadRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc read request in this Table instance.
- getReadRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getReadRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getReadRpcTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getReadShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
-
- getReadShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getReadSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getReadSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getReadType() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getReadType() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the read type for this scan
- getReadyToWriteCount() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getRealCacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getRealUser() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getRealUser(User) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- getRealUser(User) - Method in interface org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProvider
-
Returns the "real" user, the user who has the credentials being authenticated by the remote
service, in the form of an UserGroupInformation
object.
- getReason() - Method in class org.apache.hadoop.hbase.client.BalancerRejection
-
- getReason() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getReassigns() - Method in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure.UnknownServerVisitor
-
- getReceiveTime() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The timestamp when the call is constructed.
- getReceiveTime() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Builds a TableRecordReader.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in interface org.apache.hadoop.hbase.hbtop.mode.ModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
-
- getRecords(ClusterMetrics, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
-
- getRecords() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Creates a new record writer.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Creates a new record writer.
- getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the connection to ZooKeeper.
- getRecoveredEditsWriter(TableName, byte[], long) - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
Get a writer and path for a log starting at the given entry.
- getRecoveredHFiles(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getRecoveredHFilesDir(Path, String) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getRecoveredQueueStartPos() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- getRecycler() - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- getRefCellTags() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- getRefCnt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
- getRefCntValue() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- getRefCntValue() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- getRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- getRefCount() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Return the ref count associated with the reader whenever a scanner associated with the reader
is opened.
- getReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getReferenceAndLinkFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getReferenceCount() - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
-
Gets the reference of the current mob file.
- getReferencedFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Get the FileStatus
of the file referenced by this StoreFileInfo
- getReferencedHFileName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the HFile name of the referenced link
- getReferencedRegionName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Region name of the referenced link
- getReferencedTableName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Table name of the referenced link
- getReferenceFilePaths(FileSystem, Path) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- getReferenceFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Get key of the given reference
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.SoftObjectPool
-
- getReferenceKey(Reference<V>) - Method in class org.apache.hadoop.hbase.util.WeakObjectPool
-
- getReferenceType() - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getRefreshIntervalMs(boolean) - Method in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- getRefreshReplicaCountChore(CatalogReplicaLoadBalanceSimpleSelector) - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- getRegex() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- getRegion() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns the region associated with this coprocessor
- getRegion() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
n
- getRegion() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.balancer.MoveRegionAction
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
Returns The RegionInfo of the region we are operating on.
- getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getRegion(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Protected Utility method for safely obtaining an HRegion handle.
- getRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
- getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
Returns the region
- getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Find the HRegion based on a region specifier
- getRegion(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRegion() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getRegion(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getRegion(RegionInfo) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get the server side
Region
interface for the specific region.
- getRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getRegion() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- getRegionAddress(RegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- getRegionAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- getRegionArchiveDir(Path, TableName, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionArchiveDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionAssignments() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionAssignmentsByServer(Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getRegionAssignmentSnapshot() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Returns the new RegionAssignmentSnapshot n
- getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByEncodedName(byte[], String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByStateOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of regions deployed on the cluster
- getRegionCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getRegionCount(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- getRegionCount(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- getRegionCount() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- getRegionCount() - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
Gets the total number of regions in namespace.
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Get region count for table
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Returns cached region count, or -1 if quota manager is disabled or table status not found
- getRegionDegreeLocalityMappingFromFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the degree of locality for
each region on each of the servers having at least one block of that region.
- getRegionDegreeLocalityMappingFromFS(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the degree of locality for
each region on each of the servers having at least one block of that region.
- getRegionDir(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns the directory for a give region
.
- getRegionDir(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns Path
to the region directory.
- getRegionDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the Path
object representing the region directory under
path rootdir
- getRegionDirFromRootDir(Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionDirFromTableDir(Path, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionDirFromTableDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getRegionDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular table dir, return all the regiondirs inside it, excluding files such as
.tableinfo
- getRegionEventDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- getRegionFailedOpen() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getRegionHashCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getRegionHashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getRegionHFileReferences(SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- getRegionId() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns the regionId
- getRegionId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionId.
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the regionId
- getRegionIdFromOp(Row) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
Get regionId from Ops such as: get, put, delete.
- getRegionIndex(Pair<byte[][], byte[][]>, byte[]) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Get the region info for the passed region name.
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns region information for the region this coprocessor is running on
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Returns Target Region's RegionInfo or null if not available or pertinent.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getRegionInfo(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
This method implements Admin getRegionInfo.
- getRegionInfo(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get RegionInfo from Master using content of RegionSpecifier as key.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.normalizer.NormalizationTarget
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- getRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
- getRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the
RegionInfo
that describe this on-disk region view
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns region information for this region
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Returns The RegionInfo for this scanner.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the parent region info hosting this store
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.OnlineEntry
-
- getRegionInfoColumn() - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column qualifier for serialized region info
- getRegionInfoColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized region info
- getRegionInfoFileContent(RegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
n * @return Content of the file we write out to the filesystem under a region n
- getRegionInfoForDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the default replicaId (0).
- getRegionInfoForFS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionInfoForFs(RegionInfo) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns the regionInfo object to use for interacting with the file system.
- getRegionInfoForReplica(RegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the RegionInfo for the given replicaId.
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- getRegionInfoList(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Fetches all Regions for a table.
- getRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
This map contains the state of all hbck items.
- getRegionInfoResponse(MasterProcedureEnv, ServerName, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
Raw call to remote regionserver to get info on a particular region.
- getRegionInfoResponse(MasterProcedureEnv, ServerName, RegionInfo, boolean) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- getRegionInfosFromManifest(SnapshotManifest) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getRegionInfoWithLargestEndKey(RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- getRegionLoad(RpcController, AdminProtos.GetRegionLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRegionLoadCost(Collection<BalancerRegionLoad>) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadAsRateFunction
-
- getRegionLoadCost(Collection<BalancerRegionLoad>) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- getRegionLocalityMappingFromFS(Configuration, String, int, Map<String, Map<String, Float>>) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get either the mapping between the
region name and its best locality region server or the degree of locality of each region on
each of the servers having at least one block of that region.
- getRegionLocation(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Result, RegionInfo, int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and
replicaId.
- getRegionLocation(TableName, byte[], int, RegionLocateType, boolean, long) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionLocation(TableName, byte[], int, RegionLocateType, long) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionLocation(TableName, byte[], RegionLocateType, boolean, long) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionLocation(TableName, byte[], RegionLocateType, long) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Finds the region with the given replicaId
on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Find region location hosting passed row
- getRegionLocation(TableName, byte[], boolean) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getRegionLocation(byte[], int, boolean) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Get the region location for the passed region name.
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], int) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation(byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region with the given replica id on which the given row is being served.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns the region's hostname
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getRegionLocation(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Result, RegionInfo, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and
replicaId.
- getRegionLocation(int) - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the first not-null region location in the list
- getRegionLocation(ByteBuffer, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getRegionLocationByRegionName(byte[]) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the region location from the list for matching regionName, which can be regionName or
encodedRegionName
- getRegionLocationInCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns an HRegionLocationList extracted from the result.
- getRegionLocations(int, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
Get the region locations for meta region.
- getRegionLocations(TableName, byte[], int, RegionLocateType, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- getRegionLocations(TableName, byte[], RegionLocateType, boolean, long) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
-
- getRegionLocations(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getRegionLocations(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Find all the replicas for the region on which the given row is being served.
- getRegionLocations(boolean, int, ClusterConnection, TableName, byte[]) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns an HRegionLocationList extracted from the result.
- getRegionLocations() - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getRegionLocationsForPrepare(byte[]) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Fetch region locations for the row.
- getRegionLocationsForReopen(List<HRegionLocation>) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getRegionLocationsInternal(TableName, byte[], int, RegionLocateType, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- getRegionLocationWithEncodedName(AsyncTable<?>, byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the HRegionLocation from meta for the given encoded region name
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getRegionLocator() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2.TableInfo
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getRegionLocator(byte[]) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Retrieve a regionLocator for the table.
- getRegionLock(String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getRegionManifestPath(Path, SnapshotProtos.SnapshotRegionManifest) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- getRegionManifests() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot
- getRegionManifestsMap() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot.
- getRegionMap() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getRegionMaxSeqIdInStores() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get
RegionMetrics
of all regions hosted on a regionserver for a table.
- getRegionMetrics(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server.
- getRegionMetrics(ServerName, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get a list of
RegionMetrics
of all regions hosted on a region server for a table.
- getRegionMetrics(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getRegionMetrics(ServerName, TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getRegionMetrics(ServerName, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegionMetrics(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegionMetrics(ServerName, TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegionMetrics(AdminProtos.GetRegionLoadRequest, ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegionMetrics() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- getRegionMetrics() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRegionMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns region load metrics
- getRegionMetrics() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getRegionMetrics(ServerName, TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getRegionName(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
If the input is a region name, it is returned as is.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getRegionName() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the regionName as an array of bytes.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.SlowLogParams
-
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the encoded region name for the region this plan is for.
- getRegionName() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets region name
- getRegionName() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
-
- getRegionName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getRegionName() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the region name
- getRegionName() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getRegionName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the region.
- getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getRegionName() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns Region name as a String for use in logging, etc.
- getRegionNameAsString() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Region name as a String for use in logging, etc.
- getRegionNameAsString(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString(RegionInfo, byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns Region name as a String for use in logging, etc.
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getRegionNameAsStringForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameAsStringForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the region name for display.
- getRegionNameForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameFromManifest(SnapshotProtos.SnapshotRegionManifest) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Extract the region encoded name from the region manifest
- getRegionNames(RegionLocations) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionNames(HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- getRegionNames(List<HRegionLocation>) - Static method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getRegionNameToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the regioninfo for a region
- getRegionNode(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- getRegionNormalizer(Configuration) - Static method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerFactory
-
Create a region normalizer from the given conf.
- getRegionNormalizerChore() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- getRegionNormalizerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionNormalizerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ScanModifyingObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- getRegionObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationObserver
-
- getRegionObserver() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Observer/Service Getters
- getRegionObserver() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Observer/Service Getters
- getRegionObserver() - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- getRegionOpenAndInitThreadPool(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
- getRegionOverThreshold() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getRegionPlans() - Method in class org.apache.hadoop.hbase.client.BalancerDecision
-
- getRegionReferenceAndLinkFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionReferenceFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionReplicaStoreFileRefreshMultiplier(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- getRegionReplication() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Returns the configured replicas per region
- getRegionReplication() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Returns the configured replicas per region
- getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns the configured replicas per region
- getRegionReplication(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getRegionReplication(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getRegionReplication(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getRegionReportPercent(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Extracts the percent of Regions for a table to have been reported to enable quota violation
state change.
- getRegionReportPercent(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Extracts the percent of Regions for a table to have been reported to enable quota violation
state change.
- getRegionResult(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets the result in hbase:meta for the specified region.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get all the online regions on a region server.
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the regions of a given table.
- getRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online regions of the specified table.
- getRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions of a table in this RS.
- getRegions() - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions in this RS.
- getRegions(List<HBaseProtos.RegionSpecifier>, CacheEvictionStatsBuilder) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Find the List of HRegions based on a list of region specifiers
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Returns the total number of regions served by the cluster
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the list of regions served by the region server
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Returns the regions
- getRegions(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Returns List of Regions associated with this server
.
- getRegions(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getRegions(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getRegionScanner(Scan) - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- getRegionScanner(ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRegionScannerHolder(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Returns The associated RegionScannerHolder for scannerId
or null.
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
n * @return region server
- getRegionServer() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
Returns the region server
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the RegionServerAccounting for this Region Server
- getRegionServerAddresses() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Get all the region server addresses.
- getRegionServerAddresses() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getRegionServerCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionServerCount(Connection) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
Alternative getCurrentNrHRS which is no longer available.
- getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the RegionServer filter regex
- getRegionServerFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerGroup() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Get the region server group this table belongs to.
- getRegionServerGroup() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getRegionServerGroup() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getRegionServerImplementation(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServerIndex(ServerName) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerList(List<String>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegionServerObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessor
-
- getRegionServerObserver() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getRegionServerObserver() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplication
-
- getRegionServerOfRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionServerQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerQuotaCache() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- getRegionServerQuotaLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified region server.
- getRegionServerRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRegionServerRpcQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerRpcQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the live server list.
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Retrieve all current live region servers including decommissioned if excludeDecommissionedRS is
false, else non-decommissioned ones only
- getRegionServers() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServers(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Returns Read-only list of region server threads.
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the live region servers
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get a list of all the addresses of all the available region servers for this peer cluster, or
an empty list if no region servers available at peer cluster.
- getRegionServers() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerAddressTracker
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.HasRegionServerServices
-
Deprecated.
Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors
-
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors
-
- getRegionServersInZK(ZKWatcher) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getRegionServersOfTable(RegionLocator) - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
- getRegionServerSpaceQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerSpaceQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getRegionServerSpaceQuotaSnapshots(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getRegionServerStub(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getRegionServerToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regionserver to region map
- getRegionServerVersion(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerVersion(ServerName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getRegionServices() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getRegionServicesForStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns store services for this region, to access services required by store level needs
- getRegionsFromMeta(TreeMap<String, HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Get the number of regions in transition.
- getRegionsInTransitionInRS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionsInTransitionInRS() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Get the regions that are currently being opened or closed in the RS
- getRegionsInTransitionOrderedByTimestamp() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionSize(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
Returns size of given region in bytes.
- getRegionSize(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- getRegionSize(RegionInfo) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns the size for the give region if one exists.
- getRegionSize(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- getRegionSizeMap() - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
- getRegionSizeMB(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Returns the size in MB from the most recent RegionLoad for region
- getRegionSizeMb() - Method in class org.apache.hadoop.hbase.master.normalizer.NormalizationTarget
-
- getRegionSizeMB(RegionInfo) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Returns size of region in MB and if region is not found than -1
- getRegionSizeStore() - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
- getRegionSizeStore() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns the
RegionSizeStore
tracking filesystem utilization by each region.
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionsMovement(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Return how many regions will move per table since their primary RS will change
- getRegionsMovePlan(boolean) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- getRegionsOfFavoredNode(ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getRegionsOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns Return online regions of table; does not include OFFLINE or SPLITTING regions.
- getRegionsOfTable(TableName, Predicate<RegionStateNode>) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns Return the regions of the table and filter them.
- getRegionsOfTableForDeleting(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Get the regions for deleting a table.
- getRegionsOfTableForEnabling(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Get the regions for enabling a table.
- getRegionsOfTableForReopen(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Get the regions to be reopened when modifying a table.
- getRegionsOnCrashedServer(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure
-
If no Regions found in Master context, then we will search hbase:meta for references to the
passed server.
- getRegionsOnCrashedServer(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Returns List of Regions on crashed server.
- getRegionsOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Returns the regions hosted by the specified server.
- getRegionSplitEditsPath(TableName, byte[], long, String, String, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Path to a file under RECOVERED_EDITS_DIR directory of the region found in logEntry
named for the sequenceid in the passed logEntry
: e.g.
- getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the regionSplitLimit
- getRegionSplitPolicyClassName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
This gets the class associated with the region split policy which determines when a region
split should occur.
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This gets the class associated with the region split policy which determines when a region
split should occur.
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This gets the class associated with the region split policy which determines when a region
split should occur.
- getRegionsRecoveryChoreInterval(Configuration) - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- getRegionsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRegionsStateInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionStartKeys(List<RegionLocator>, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Return the start keys of all of the regions in this table, as a list of ImmutableBytesWritable.
- getRegionState(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionState(String) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionState(Result, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
Pull the region state from a catalog table
Result
.
- getRegionState(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getRegionState() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getRegionStateColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized region state
- getRegionStateColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized region state
- getRegionStateNode(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionStateNode() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- getRegionStateNode(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getRegionStateNodeFromName(byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionStateNodes(TableName, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionStateNodes() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns A view of region state nodes for all the regions.
- getRegionStates() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionStates() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns A snapshot of region state nodes for all the regions.
- getRegionStates() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- getRegionStatesCount(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Provide regions state count for given table.
- getRegionStatesInTransition() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getRegionStatesInTransition() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getRegionStatesInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getRegionStateStore() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of new regions added during the on-disk restore.
- getRegionsToFlush(String) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Get the list of regions to flush for the table on this server It is possible that if a region
moves somewhere between the calls we'll miss the region.
- getRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of regions removed during the on-disk restore.
- getRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of 'restored regions' during the on-disk restore.
- getRegionsToSnapshot(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Determine if the snapshot should be handled on this server NOTE: This is racy -- the master
expects a list of regionservers.
- getRegionsWithoutValidFavoredNodes() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return the regions without favored nodes
- getRegionToRegionServerMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get region to region server map
- getRegionTransitionState(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getRegionWALFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- getRegistredMBeans(ObjectName, MBeanServer) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getRegistry(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionRegistryFactory
-
Returns The connection registry implementation to use.
- getRelativeOffset(int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getRelativeOffsetForByteBuff(ByteBuff, int, int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- getRemaining() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getRemainingRpcTimeout(RpcCall, HBaseRpcController, long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRemainingTime(int) - Method in class org.apache.hadoop.hbase.client.RetryingTimeTracker
-
- getRemainingTime(TimeUnit, long) - Static method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil
-
Returns Time remaining as milliseconds.
- getRemoteAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns Address of remote client in this call
- getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns Address of remote client if a request is ongoing, else null
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getRemoteClientIpAndPort() - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Returns Remote client's ip and port else null if can't be determined.
- getRemoteDispatcher() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getRemoteInetAddress(MetricsConnection) - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- getRemoteInetAddress(int, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns Get remote side's InetAddress
- getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the remote side ip address when invoked inside an RPC Returns null incase of an error.
- getRemotePort() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns Port of remote address in this call
- getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getRemoteProcedure(long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRemoteProcedure() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteOperation
-
- getRenewer() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Returns the account name that is allowed to renew the token.
- getReopenMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getReopenMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getReopenProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for reopen procedure
- getReopenStatus(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Used by the client (via master) to identify if all regions have the schema updates
- getReplBarrierFamilyDescForMeta() - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getReplicableEdits() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Gets the number of edits eligible for replication read from this source queue logs so far.
- getReplicableHFiles(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getReplicableHFiles(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all hfile references in the given peer.
- getReplicableHFiles(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getReplicableHFiles0(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Action
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns the region replica id
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns region replica id where Query will fetch data from.
- getReplicaId() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns returns region replica id
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the region replica id
- getReplicaId() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getReplicaId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the replica id of this region.
- getReplicaId() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
Get the replica id of this region.
- getReplicaId() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getReplicaLoad(List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- getReplicaLocationOrFail(Action) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getReplicationBarrier(Cell) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarrier(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarrierResult(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarrierResult(Connection, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationBarriers(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getReplicationDelay() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getReplicationDelay() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getReplicationEndpoint() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getReplicationEndpoint() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns the replication endpoint used by this replication source
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getReplicationLoad(ServerName[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell n
- getReplicationLoadSink() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell n
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getReplicationLoadSourceEntries() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getReplicationLoadSourceMap() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Call directly from client such as hbase shell
- getReplicationLoadSourceMap() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getReplicationManager() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns the replication manager
- getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Get the replication sources manager
- getReplicationPeer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Returns the configured ReplicationPeerConfig for the specified peer.
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getReplicationPeerConfig(RpcController, ReplicationProtos.GetReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getReplicationPeerConfig(RpcController, ReplicationProtos.GetReplicationPeerConfigRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the configured ReplicationPeerConfig for the specified peer
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getReplicationPeerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getReplicationPeerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getReplicationPeerManager() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getReplicationPeers() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the ReplicationPeers used by this ReplicationSourceManager
- getReplicationPeers(ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationPeerStorage(ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
- getReplicationQueueInfo() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getReplicationQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the replication queue for metrics.
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getReplicationQueueStorage() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getReplicationQueueStorage() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns The instance of queueStorage used by this ReplicationSource.
- getReplicationQueueStorage(ZKWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
- getReplicationScope() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReplicationScopes() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- getReplicationSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Get a randomly-chosen replication sink to replicate to.
- getReplicationSinkService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the object that implements the replication sink executorService.
- getReplicationSourceService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the object that implements the replication source executorService.
- getReplicationZnodesDump(ZKWatcher, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
Appends replication znodes to the passed StringBuilder.
- getReplicationZnodesDump(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
Returns a string with replication znodes and position of the replication log
- getReplSyncUpPath(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- getReport() - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- getReportTime() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getReportTimestamp() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the timestamp (server side) of generating this metrics
- getReportTimestamp() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRequest(Service, Descriptors.MethodDescriptor, ByteString) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- getRequest() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the number of requests since last report
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of write requests and read requests made to region
- getRequestCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRequestCount() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns total Number of requests from the start of the region server.
- getRequestCount() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of write requests and read requests and coprocessor service requests made by
the user
- getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getRequestCountPerSecond() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the number of requests per second.
- getRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should return any additional data that is needed on the server side to construct
the ColumnInterpreter.
- getRequestData() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
This method should return any additional data that is needed on the server side to construct
the RowProcessor.
- getRequestLog(String) - Static method in class org.apache.hadoop.hbase.http.HttpRequestLog
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the number of requests per second processed by the region server
- getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Returns Current value for bloom requests count
- getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRequestSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getRequestsPerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of requests per second.
- getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRequestURL() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the url so that users specifying the HOST HTTP header can't inject attacks.
- getRequestUser() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the user credentials associated with the current RPC request or not present if no
credentials were provided.
- getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the user credentials associated with the current RPC request or not present if no
credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getRequestUser() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getRequestUserName() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns Current request's user name or not present if none ongoing.
- getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the username for any user associated with the current RPC request or not present if no
user is set.
- getRequeueCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- getRescanNode(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getResource(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getResource(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getResourceName() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getResourceType() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getResponse(ClientProtos.CoprocessorServiceResponse, Message) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getResponse(Message, byte[]) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
- getResponse() - Method in interface org.apache.hadoop.hbase.ipc.RpcResponse
-
- getResponse() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getResponseBlockSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getResponseBlockSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getResponseBody(HttpResponse) - Static method in class org.apache.hadoop.hbase.rest.client.Client
-
Returns the response body of the HTTPResponse, if any, as an array of bytes.
- getResponseCellSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
The size of response cells that have been accumulated so far.
- getResponseCellSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getResponseExceptionSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getResponseExceptionSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getResponseSize() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getResponseSize() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- getResponseSizeBytes() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getRestoreAcl() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Exposed for Testing: HBASE-26462
- getRestoreAcl() - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Exposed for Testing: HBASE-26462
- getRestoreDir() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getRestoreSFT(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
-
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
-
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
-
- getRestrictedSplitPoint(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
Returns a restricted split point.
- getRESTVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
Returns the REST gateway version
- getResult() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
Returns It is used only for CheckAndMutate operations with Increment/Append.
- getResult(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getResult() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- getResult() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
-
- getResult(long) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner.HFileDeleteTask
-
- getResult(long) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- getResult() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns the serialized result if any, otherwise null
- getResult(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns the detailed result code
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
n
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
Obtain the processing result.
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrContext
-
- getResultOrException(ClientProtos.Result, int) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getResultOrException(Exception, int) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getResultOrException(ClientProtos.ResultOrException.Builder, int) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getResultOrProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getResults() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getResults() - Method in interface org.apache.hadoop.hbase.client.AsyncRequestFuture
-
- getResults() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getResults() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getResults() - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
-
Returns Collected results; wait till visits complete to collect all possible results
- getRetainedRegionRWRequestsCnt() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Returns the retained metrics of region's read and write requests count
- getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getRetries() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getRetries() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- getRetriesCount(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getRetryCounter() - Static method in class org.apache.hadoop.hbase.regionserver.handler.HandlerUtil
-
Get an exponential backoff retry counter.
- getRetryInQueue() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getRetryPauseTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getReverseScanResult(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion revision number for the root directory
- getRight() - Method in class org.apache.hadoop.hbase.master.janitor.MetaFixer.Either
-
- getRitCount() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getRitDuration() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getRITThreshold() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getRNG() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getRNG() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Returns the number of root-level blocks in this block index
- getRootBlockDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- getRootBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase root dir.
- getRootDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the path for the root data directory
- getRootDirFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRootIndexHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getRootIndexHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRootIndexMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getRootIndexMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns The current total size of root-level indexes for the region, in KB.
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- getRootProcedureId(Map<Long, Procedure<T>>, Procedure<T>) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Helper to lookup the root Procedure ID given a specified procedure.
- getRootProcedureId(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getRootProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getRootSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
Returns the size of this chunk if stored in the root index block format
- getRow() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the row
- getRow() - Method in class org.apache.hadoop.hbase.client.Cursor
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's row n
- getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the delete's row n
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Result
-
Method for retrieving the row key that corresponds to the row from which this Result was
created.
- getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getRow() - Method in interface org.apache.hadoop.hbase.client.Row
-
Returns The row.
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getRow() - Method in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
-
- getRow(int) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- getRow() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowAccess() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getRowArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getRowArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getRowArray() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getRowArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
Implement Cell interface
- getRowArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getRowAsInt(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the rowkey bytes of the given cell into an int value n * @return rowkey as int
- getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Deprecated.
- getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
misc
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getRowByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Returns a count of the rows in the region where this coprocessor is loaded.
- getRowFilter(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- getRowForRegion(RegionInfo) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- getRowKey(TooSlowLog.SlowLogPayload) - Static method in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
Create rowKey: currentTime APPEND slowLogPayload.hashcode Scan on slowlog table should keep
records with sorted order of time, however records added at the very same time could be in
random order.
- getRowKey() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- getRowKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getRowKeyLength() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getRowKeyOffset() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getRowKeyRegEx(byte[], String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getRowLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of row bytes.
- getRowLength() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getRowLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Row length
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Get an exclusive ( write lock ) lock on a given row.
- getRowLock(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRowLock(byte[], boolean, Region.RowLock) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRowLock(Lock) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- getRowLock(byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Get a row lock for the specified row.
- getRowLockInternal(byte[], boolean, Region.RowLock) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first row byte
- getRowOffset() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Row offset
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's offset per row per column family (#kvs to be skipped)
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Method for retrieving the scan's offset per row per column family (#kvs to be skipped)
- getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where row bytes start
- getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getRowPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getRowPrefixCell(Cell) - Method in class org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
-
- getRowProcessorPB(RowProcessor<S, T>) - Static method in class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
-
- getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getRowResource(String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRowResourceWithSuffixGlobbing(String, String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRows() - Method in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
-
- getRows() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Returns the rows
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowsToLock() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
Rows to lock while operation.
- getRowString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getRPC() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced by this Handler.
- getRPC(boolean) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced by this Handler.
- getRpcCall() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- getRpcCall() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- getRpcCallSize(CallRunner) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getRpcClient() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
For tests only.
- getRpcClientClass(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
- getRpcController() - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- getRpcController() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getRpcControllerCellScanner() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
Get the RpcController CellScanner.
- getRpcControllerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns Connection's RpcControllerFactory instance
- getRpcControllerFactory() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getRpcControllerFactory() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getRpcFullScanRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of full region rpc scan requests to this region server.
- getRpcFullScanRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRpcGetRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc get requests to this region server.
- getRpcGetRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRpcMultiRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc multi requests to this region server.
- getRpcMultiRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRpcMutateRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc mutate requests to this region server.
- getRpcMutateRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRpcName(Descriptors.MethodDescriptor) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
Retrieve the $method
value from md
.
- getRpcPackageAndService(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
Retrieve the combined $package.$service
value from sd
.
- getRPCPacketLength() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCPacketLength() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced by this Handler.
- getRPCQueueTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCQueueTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the queue time for the currently running RPC on the monitored Handler.
- getRpcQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRpcRefCount(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getRpcRefCount(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getRpcRetryingCallerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns Connection's RpcRetryingCallerFactory instance
- getRpcRetryingCallerFactory() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getRpcs() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns the rpcs implementation for all current procedures
- getRpcs() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Package exposed.
- getRpcScanRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of rpc scan requests to this region server.
- getRpcScanRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getRpcScheduler() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRpcSchedulerFactoryClass() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getRpcSchedulerFactoryClass() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRpcServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns a reference to the region server's RPC server
- getRPCStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the start time for the currently running RPC on the monitored Handler.
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- getRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc request in this Table instance.
- getRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getRpcTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getRsAdmin() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- getRsAdmin(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
n * @return Admin interface for the remote regionserver named sn
n * @throws
RetriesExhaustedException wrapping a ConnectException if failed
- getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Gets RSGroupInfo
for the given group name.
- getRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getRSGroup(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupMappingScript
-
- getRSGroupAssignmentsByTable(TableStateManager, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
This is an EXPENSIVE clone.
- getRSGroupInfo(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Gets RSGroupInfo
for given group name.
- getRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- getRSGroupInfo(RpcController, RSGroupAdminProtos.GetRSGroupInfoRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- getRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- getRSGroupInfo(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getRSGroupInfo(Result) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- getRSGroupInfo(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- getRSGroupInfoOfServer(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfServerRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoOfServerResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- getRSGroupInfoOfTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Gets RSGroupInfo
for the given table's group.
- getRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- getRSGroupInfoOfTable(RpcController, RSGroupAdminProtos.GetRSGroupInfoOfTableRequest, RpcCallback<RSGroupAdminProtos.GetRSGroupInfoOfTableResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- getRSGroupInfoOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- getRSGroupOfServer(Address) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Retrieve the RSGroupInfo a server is affiliated to
- getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- getRSGroupOfServer(Address) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Gets the group info of server.
- getRSGroupOfServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getRSGroupOfTable(TableName) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Get the group membership of a table
- getRSGroupOfTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- getRSMobFileCleanerChore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRsNode(ServerName) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getRsNode(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get full znode name for given region server
- getRsNode(ServerName) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getRsPath(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- getRsPorts() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- getRSReports() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Returns a snapshot of rsReports
- getRSRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRunningTasks() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.TrackingThreadPoolExecutor
-
- getSampleCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Returns the number of samples kept by the estimator
- getSamplingResult() - Method in class org.apache.hadoop.hbase.util.ReservoirSample
-
- getSaslAuthMethod() - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslAuthenticationProvider
-
- getSaslAuthMethod() - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslAuthenticationProvider
-
- getSaslAuthMethod() - Method in class org.apache.hadoop.hbase.security.provider.GssSaslAuthenticationProvider
-
- getSaslAuthMethod() - Method in interface org.apache.hadoop.hbase.security.provider.SaslAuthenticationProvider
-
Returns the attributes which identify how this provider authenticates.
- getSaslAuthMethod() - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslAuthenticationProvider
-
- getSaslMechanism() - Method in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
Returns the SASL mechanism used by this authentication method.
- getSaslPropsResolver(SaslDataTransferClient) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslAdaptor
-
- getSaslQOP() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- getSaslQOP() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
-
- getSaslQop() - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Gets the scan defining the actual details like columns etc.
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a Scan object from the stored string representation.
- getScan() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getScan() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
Returns a copy of the Scan object.
- getScanAsString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a scan string
- getScanBalancer() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getScanDetailsWithId(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getScanDetailsWithRequest(ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getScanForTableName(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
This method creates a Scan object that will only scan catalog rows that belong to the specified
table.
- getScanForUpdateRegionReplicas(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getScanFromCommandLine(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
- getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getScanLabelGenerators(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getScanLimit() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Used internally accumulating metrics on scan.
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- getScanMetrics() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Returns the scan metrics, or null
if we do not enable metrics.
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getScanMetrics() - Method in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- getScanMetrics() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getScanner(Configuration, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(Configuration, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(Configuration, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Create a Scanner on this file.
- getScanner(Configuration, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Create a Scanner on this file.
- getScanner() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- getScanner() - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Internal use only.
- getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Creates the scanner for the given read point
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, List<KeyValueScanner>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Return a scanner for both the memstore and the HStore files.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return an iterator that scans over the HRegion, returning the indicated columns and rows
specified by the
Scan
.
- getScanner(Scan, List<KeyValueScanner>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return an iterator that scans over the HRegion, returning the indicated columns and rows
specified by the
Scan
.
- getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Returns The outstanding RegionScanner for scannerId
or null if none found.
- getScanner(long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Creates the scanner for the given read point
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Returns the scanner associated with the specified ID.
- getScanner() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
Returns the Scanner associated with the specified Id.
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
-
- getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getScannerOrder() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Get the order of this KeyValueScanner.
- getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- getScannerOrder() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This method is protected under HStore read lock.
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Get all scanners with no filtering based on TTL (that happens further down the line).
- getScanners(boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Get all scanners with no filtering based on TTL (that happens further down the line).
- getScanners(List<HStoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Create scanners on the given files and if needed on the memstore with no filtering based on TTL
(that happens further down the line).
- getScanners(List<HStoreFile>, boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Create scanners on the given files and if needed on the memstore with no filtering based on TTL
(that happens further down the line).
- getScanners(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- getScanners() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getScannersCount() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getScannersForCompaction(Collection<HStoreFile>, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Get scanners for compaction.
- getScannersForStoreFiles(Collection<HStoreFile>, boolean, boolean, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files.
- getScannersForStoreFiles(Collection<HStoreFile>, boolean, boolean, boolean, boolean, ScanQueryMatcher, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files, And set the
ScanQueryMatcher for each store file scanner for further optimization
- getScannerTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScannerVirtualTime(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get the vtime associated with the scanner.
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getScanQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the scan queue for metrics when use RWQueueRpcExecutor.
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getScanQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getScanRegionState() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getScanReplicaId() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScanResource(String, int, String, String, List<String>, int, int, long, long, boolean, boolean, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- getScanShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
-
- getScanShare(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getScanStart() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getScanTable() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- getScanTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get the timeout of a single operation in a scan.
- getScanTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getScanTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getScanTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getScanTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getScanType(CompactionRequestImpl) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.InternalScannerFactory
-
- getScanType(CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor.StripeInternalScannerFactory
-
- getScheduler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getScheduler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getScheduler() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get the number of regions of the table that have been updated by the alter.
- getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScheme(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getSchemePrefix() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getScope() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns the scope tag
- getScope() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getScope(Configuration, String, Object) - Static method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Returns the scope for a MetricsConnection based on the configured
MetricsConnection.METRICS_SCOPE_KEY
or
by generating a default from the passed clusterId and connectionObj's hashCode.
- getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking the scope.
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- getSecond() - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
-
- getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getSecondaryAndTertiary(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getSecondaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- getSecondLevelCache() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Resolves a key for the given subject nn * @return a key for the given subject
- getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getSecureBulkLoadManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getSecureBulkLoadManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the set of supported security capabilities.
- getSecurityCapabilities() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Returns the list of supported security capabilities.
- getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getSecurityCapabilities(RpcController, MasterProtos.SecurityCapabilitiesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns the security capabilities in effect on the cluster
- getSecurityCapabilities() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getSeekCount() - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getSegment() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Private Methods
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Returns an ordered list of segments from most recent to oldest in memstore
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getSegments() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getSegmentsCellsCount(List<? extends Segment>) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getSegmentsHeapSize(List<? extends Segment>) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getSegmentsKeySize(List<? extends Segment>) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getSegmentsOffHeapSize(List<? extends Segment>) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getSelectedRecord() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- getSelectionTime() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns compaction request creation time in milliseconds
- getSelectionTime() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- getSeqid() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Returns This events' sequence id.
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getSeqNum() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- getSeqNum() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionInfo
-
- getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column qualifier for seqNum column for replicaId
- getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for seqNum column for replicaId
- getSeqNumDuringOpen(Result, int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
The latest seqnum that the server writing to meta observed when opening the region.
- getSeqNumDuringOpen(Result, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
The latest seqnum that the server writing to meta observed when opening the region.
- getSequenceId() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getSequenceId() - Method in interface org.apache.hadoop.hbase.Cell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getSequenceId() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
A region-specific unique monotonically increasing sequence ID given to each Cell.
- getSequenceId() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.KeyValue
-
used to achieve atomic operations in the memstore.
- getSequenceId() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.SequenceId
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
SequenceId is only available post WAL-assign.
- getSequenceIdFiles(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getSequenceOnRingBuffer() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getSerializedLength() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the length of the ByteBuffer required to serialized the object.
- getSerializedLength() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getSerializedSize() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Serialized size (defaults to include tag length if has some tags).
- getSerializedSize(boolean) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
KeyValue format
<4 bytes keylength> <4 bytes valuelength> <2 bytes rowlength>
<row> <1 byte columnfamilylength> <columnfamily> <columnqualifier>
<8 bytes timestamp> <1 byte keytype> <value> <2 bytes tagslength>
<tags>
- getSerializedSize() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Returns Serialized size (defaults to include tag length).
- getSerializedSize() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getSerializedSize(Cell, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
Override by just returning the length for saving cost of method dispatching.
- getSerializedSize() - Method in class org.apache.hadoop.hbase.SizeCachedKeyValue
-
Override by just returning the length for saving cost of method dispatching.
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
-
- getSerializedSize(boolean) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getSerializer(Class<Cell>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
-
- getSerializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
Deprecated.
- getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getSerialPeerIdsBelongsTo(TableName) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- getSerialReplicationRegionPeerNode(String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
Put all regions under /hbase/replication/regions znode will lead to too many children because
of the huge number of regions in real production environment.
- getServer() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- getServer() - Method in class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
-
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- getServer() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getServer() - Method in class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
-
- getServerClass() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getServerColumn(int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column qualifier for server column for replicaId
- getServerColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for server column for replicaId
- getServerConfigurationOnOneLine(ZooKeeperServer) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getServerConnectors() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getServerCrashMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- getServerCrashMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- getServerCrashProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Returns Set of metrics for assign procedure
- getServerFromFavoredNode(List<ServerName>, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- getServerImpl(Configuration) - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- getServerInfo(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get some information of the region server.
- getServerLock(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getServerName(Result, int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getServerName() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- getServerName() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
Returns server name
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Returns Hosting Server's ServerName
- getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the server name so that users specifying the HOST HTTP header can't inject attacks.
- getServerName(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
The procedure could be restarted from a different machine.
- getServerName() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- getServerName() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getServerName(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getServerName() - Method in interface org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface
-
Returns Name of this server instance.
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- getServerName(Result, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionInfo
-
- getServerName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- getServerName() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- getServerName() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
Returns The unique server name for this server.
- getServerName() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getServerName() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerName() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- getServerName() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getServerName() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo.OnlineEntry
-
- getServerNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getServerNameColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized region state
- getServerNameForRegion(RegionInfo, Admin, Connection) - Static method in class org.apache.hadoop.hbase.util.MoveWithAck
-
Get servername that is up in hbase:meta hosting the given region.
- getServerNameFromWALDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Pulls a ServerName out of a Path generated according to our layout rules.
- getServerNameFromWALDirectoryName(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
This function returns region server name from a log file name which is in one of the following
formats:
hdfs://<name node>/hbase/.logs/<server name>-splitting/...
hdfs://<name node>/hbase/.logs/<server name>/...
- getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerNameOrEmptyString(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getServerNamesFromHBase(Set<ServerName>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getServerNamesFromThrift(Set<TServerName>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getServerNamesFromWALDirPath(PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Returns listing of ServerNames found by parsing WAL directory paths in FS.
- getServerNode(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns Pertinent ServerStateNode or NULL if none found (Do not make modifications).
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getServerOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface
-
Given an operation type we can take decisions about what to do with pending operations.
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- getServerOperationType() - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- getServerPrincipal(Configuration, SecurityInfo, InetAddress) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getServerPriority(ServerProcedureInterface) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
Return the priority for the given procedure.
- getServerQueue(ServerName, ServerProcedureInterface) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getServerRegionsMap() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServers() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getServers() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get list of servers.
- getServersByLoad() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- getServersFromRack(String) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getServersName() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
- getServersName() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getServersName() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
-
Gets the statistics from the given server.
- getServersToCompact(Set<ServerName>) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- getServerUserRegions(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Get the user regions a given server is hosting.
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
Returns the servlet container version
- getServerWALsBelongTo() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- getServerWALsBelongTo() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getServerWALsBelongTo() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
The queue of WALs only belong to one region server.
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.CoprocessorService
-
Deprecated.
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.SingletonCoprocessorService
-
Deprecated.
- getService() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The service of this call.
- getService(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getService() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getServiceAndInterface(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getServiceInterface() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- getServiceInterface(List<RpcServer.BlockingServiceAndInterface>, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getServiceName() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getServiceName(Descriptors.ServiceDescriptor) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Returns the name to use for coprocessor service calls.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.MasterCoprocessorService
-
Deprecated.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionCoprocessorService
-
Deprecated.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionServerCoprocessorService
-
Deprecated.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
-
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Just returns a reference to this object, which implements the RowCounterService interface.
- getServices() - Method in interface org.apache.hadoop.hbase.Coprocessor
-
Coprocessor endpoints providing protobuf services should override this method.
- getServices() - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- getServices() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns list of blocking services and their security info classes that this server supports
- getServices() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
By default, put up an Admin and a Client Service.
- getServices() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- getServices() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- getServices() - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getServices() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSettingsQualifierForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierForUserTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierRegexForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierRegexForUserTable(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSeverity() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- getsFromHBase(List<Get>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getsFromThrift(List<TGet>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TGet
s (Thrift) into a list of
Get
s (HBase).
- getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
Returns shared data between all instances of this coprocessor
- getSharedData() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- getSharedLockCount() - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- getSharedLockCount() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getSharedLockCount() - Method in interface org.apache.hadoop.hbase.procedure2.LockStatus
-
Get the number of procedures which hold the shared lock.
- getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the percentage of the shared store files
- getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files shared
- getShippedBytes() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSource
-
- getShippedBytes() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- getShippedOps() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getShippedOps() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getShippedOps() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getShort() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the short value at the current position.
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the short value at the given index.
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Fetches the short at the given index.
- getShort(int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getShort() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the short value at the current position.
- getShort() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getShort(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getShort(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getShort() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the short value at index
- getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next short value from this range.
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Fetches the short value at the given offset from current position.
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- getShortAfterPosition(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- getShortCircuitBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getShortCircuitBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read locally through HDFS short circuit.
- getShortCircuitBytesRead() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getShortCompactions() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Returns the shortCompactions thread pool executor
- getShortHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
Returns an abbreviated summary of hist
.
- getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
Don't do any fancy Block Index splitting tricks.
- getShortName() - Method in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- getShortName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the shortened version of the user name -- the portion that maps to an operating system
user name.
- getShortName() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- getShortNameToLog() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns Return a short, printable name for this region (usually encoded name) for us logging.
- getShortNameToLog() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns Return a short, printable name for this region (usually encoded name) for us logging.
- getShortNameToLog(RegionInfo...) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for hris
(usually encoded name) for us
logging.
- getShortNameToLog(List<RegionInfo>) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns a String of short, printable names for hris
(usually encoded name) for us
logging.
- getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns Return a short, printable name for this region (usually encoded name) for us logging.
- getShortNameToLog(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getShortNameToLog(List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getSidelineDir() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getSimpleComparator() - Method in interface org.apache.hadoop.hbase.CellComparator
-
- getSimpleComparator() - Method in class org.apache.hadoop.hbase.CellComparatorImpl
-
- getSimpleComparator() - Method in class org.apache.hadoop.hbase.MetaCellComparator
-
- getSimpleName() - Method in enum org.apache.hadoop.hbase.Size.Unit
-
- getSimpleProvider() - Method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Returns the provider and token pair for SIMPLE authentication.
- getSimpleProvider() - Method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Extracts the SIMPLE authentication provider.
- getSingleFactor() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getSingleSourceSourceByTable() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- getSink() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getSink(Configuration, Class) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- getSink() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- getSink() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- getSink() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperMonitor
-
- getSinkAppliedOps() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- getSinkAppliedOps() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- getSinkMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get replication Sink Metrics n
- getSinksForTesting() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- getSize() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- getSize() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- getSize() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- getSize() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of minimal buffer that could store compressed data.
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
Returns size of blocks in the cache
- getSize() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getSize() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Used to calculate the request call queue size.
- getSize() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getSize() - Method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- getSize() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getSize() - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.SnapshotWithSize
-
- getSize() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager.SizeSnapshotWithTimestamp
-
- getSize() - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Returns the size of the region.
- getSize() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
-
- getSize() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns total size of all StoreFiles in compaction
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Gets the total size of all StoreFiles in compaction
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns aggregate size of HStore
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Size of the Hfile n
- getSize() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- getSize(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- getSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
Returns the file size
- getSize() - Method in class org.apache.hadoop.hbase.util.Bytes
-
- getSizeCoefficients(Class, boolean) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
The estimate of the size of a class instance depends on whether the JVM uses 32 or 64 bit
addresses, that is it depends on the size of an object reference.
- getSizeData() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- getSizeOfCleaners() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- getSizeOfLatestPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getSizeOfLogQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the sizeOfLogQueue n
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getSizeOfStoreFile(TableName, FileArchiverNotifierImpl.StoreFileReference) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Computes the size of the store files for a single region.
- getSizeOfStoreFile(TableName, String, String, String) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Computes the size of the store file given its name, region and family name in the archive
directory.
- getSizeOfStoreFiles(TableName, Set<FileArchiverNotifierImpl.StoreFileReference>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Computes the size of each store file in storeFileNames
- getSizeScope() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getSkippedCount(NormalizationPlan.PlanType) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
Retrieve a count of the number of times plans of type type
were submitted but skipped.
- getSkippedCount(NormalizationPlan.PlanType) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- getSkippedEditsCounter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- getSleepInterval() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getSleepTime() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- getSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- getSlowLogPayloads(AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- getSlowLogPayloads() - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- getSlowLogPayloads(AdminProtos.SlowLogResponseRequest, NamedQueueRecorder) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSlowLogQueryFromHBase(LogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getSlowLogQueryFromThrift(TLogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getSlowLogRecordsFromHBase(List<OnlineLogRecord>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getSlowLogRecordsFromThrift(List<TOnlineLogRecord>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getSlowLogResponseFromServer(ServerName, Map<String, Object>, int, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSlowLogResponseFromServer(ServerName, Map<String, Object>, int, String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getSlowLogResponseRequest() - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- getSlowLogResponses(Map<String, Object>, Set<ServerName>, int, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSlowLogResponses(Map<String, Object>, Set<ServerName>, int, String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getSlowLogResponses(RpcController, AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSlowLogResponses(Set<ServerName>, LogQueryFilter) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getSlowLogResponses(Set<TServerName>, TLogQueryFilter) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getSmallCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getSmallCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSmallestReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getSmallQueueInitSize() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Returns the description of the snapshot being run
- getSnapshot() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Returns the description of the snapshot that is being failed
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the snapshot descriptor
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the SnapshotDescription
- getSnapshotDir(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getSnapshotDir() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the current snapshot working dir
- getSnapshotDirs(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- getSnapshotFiles(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Extract the list of files (HFiles/WALs) to copy using Map-Reduce.
- getSnapshotFilesMap(Configuration, SnapshotDescription, ExecutorService, ConcurrentHashMap<Path, Integer>, AtomicLong, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Gets the store files map for snapshot
- getSnapshotFormat(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the underlying snapshot manager
- getSnapshotManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns the underlying snapshot manager
- getSnapshotManifest(Configuration, String, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSnapshotName(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSnapShotOfAssignment(Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getSnapShotOfAssignment(Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getSnapshotQuotaObserverChore() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getSnapshotRootDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the snapshot root directory.
- getSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSnapshotScanners() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getSnapshotScanners() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getSnapshotSegments() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getSnapshotsFilesMap(Configuration, AtomicLong, AtomicLong, AtomicLong) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the map of store files based on path for all snapshots
- getSnapshotsFromTables(Admin, Set<TableName>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Computes a mapping of originating TableName
to snapshots, when the TableName
exists in the provided Set
.
- getSnapshotsInProgress() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Return the size of the snapshot(s) if any
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns size of the memstore snapshot
- getSnapshotSizeFromResult(Result) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- getSnapshotSizeQualifier(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSnapshotSizesForTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
Fetches any serialized snapshot sizes from the quota table for the tn
provided.
- getSnapshotStats(Configuration, SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSnapshotStats(Configuration, SnapshotProtos.SnapshotDescription, Map<Path, Integer>) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSnapshotsToComputeSize() - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Fetches each table with a quota (table or namespace quota), and then fetch the name of each
snapshot which was created from that table.
- getSnapshotsToScans(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- getSocketAddr(String, String, String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getSocketAddr(String, String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getSocketAddress() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSoftLimit() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getSortedTagOrdinals(List<List<Integer>>, Tag) - Static method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- getSource(String, MetricsHBaseServerWrapper) - Static method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
-
- getSource() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the source server for the plan for this region.
- getSource() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
- getSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- getSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
-
Returns return a singleton instance of MetricsUserAggregateSource or null in case of NoOp
- getSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- getSource(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the normal source for a given peer
- getSource() - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- getSource() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- getSourceFileStatus(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context, SnapshotProtos.SnapshotFileInfo) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- getSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getSourceInitializing() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the source initializing counts
- getSourceManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getSourceManager() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns the replication source manager
- getSourceMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getSourceMetrics() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns metrics of this replication source
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the normal sources of this rs
- getSpaceProto() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- getSpaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- getSpaceQuota(T) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Fetch the Quota for the given subject
.
- getSpaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- getSpaceQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSpaceQuotaRegionSizes(RpcController, QuotaProtos.GetSpaceQuotaRegionSizesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getSpaceQuotaRegionSizes(RpcController, QuotaProtos.GetSpaceQuotaRegionSizesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getSpaceQuotaSnapshotNotifier() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getSpaceQuotaSnapshots(RpcController, QuotaProtos.GetSpaceQuotaSnapshotsRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSpaceQuotaTableSizes() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Fetches the table sizes on the filesystem as tracked by the HBase Master.
- getSpaceQuotaTableSizes() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getSpaceQuotaTableSizes() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSpaceQuotaTableSizes() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getSpaceQuotaTableSizes() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getSpan() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- getSpecificStores(List<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
get stores which matches the specified families
- getSpecifiedSnapshotDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory within the given filepath to store the snapshot instance
- getSpengoPrincipal(Configuration, String) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getSplitAlgo(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplitCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Returns sorted set of edit files made by splitter, excluding files with '.temp' suffix.
- getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
-
n
- getSplitKeys(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getSplitKeys() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotInputSplit
-
- getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- getSplitLogManager() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- getSplitLogManagerCoordination() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Method to retrieve coordination for split log manager
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- getSplitLogWorkerCoordination() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Method to retrieve coordination for split log worker
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- getSplitMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- getSplitMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getSplitOrMergeTracker() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getSplitParentRegions() - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- getSplitPartSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitPlanCount() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of region split plans executed.
- getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- getSplitPlanCount() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
Deprecated.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Determines if Store should be split.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the split point for the split of this set of store files (approx.
- getSplitPoint(Collection<HStoreFile>, CellComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets the mid point of the largest file passed in as split point.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Override of getSplitPoint that determines the split point as the boundary between two stripes,
unless it causes significant imbalance between split sides' sizes.
- getSplitPointFromAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getSplitPolicy() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns split policy for this region.
- getSplitPolicyClass(TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for split procedure
- getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getSplitQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the split queue
- getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getSplitRegionInfo() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getSplitRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- getSplitRow() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
-
- getSplits(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- getSplits(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplits(Scan, SnapshotManifest, List<HRegionInfo>, Path, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplits(Scan, SnapshotManifest, List<HRegionInfo>, Path, Configuration, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- getSplits(JobContext, String, String) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
implementation shared with deprecated HLogInputFormat
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionInputFormat
-
Returns a split for each store files directory using the block location of each file as
locality reference.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat
-
- getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getSplits(Connection, TableName, RegionSplitter.SplitAlgorithm) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
- getSplitsDir(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getSplitSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitTarget() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
-
- getSplitThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getSplittingServersFromWALDir() - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Get Servernames which are currently splitting; paths have a '-splitting' suffix.
- getSplitWALManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getSplitWALManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns return null if current is zk-based WAL splitting
- getSpnegoKeytab(Configuration) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the checksum of the source files from which Hadoop was compiled.
- getSrcTrackerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- getStackIndexes() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
-
Initializes the staging directory and returns the path.
- getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getStart() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- getStartcode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns time stamp in millis of when this region server was started
- getStartCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get HRegionServer start time
- getStartCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Returns the region server's start code
- getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
-
- getStartCode() - Method in class org.apache.hadoop.hbase.ServerName
-
Return the start code.
- getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column qualifier for server start code column for replicaId
- getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for server start code column for replicaId
- getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting and ending row keys for every region in the currently open table.
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getStartKey() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns the startKey
- getStartKey() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns the startKey.
- getStartKey(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Gets the start key from the specified region name.
- getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns the startKey
- getStartKey(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getStartKey() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getStartKey() - Method in class org.apache.hadoop.hbase.mob.MobFileName
-
Gets the hex string of the md5 for a start key.
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Returns the start key
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Returns the start key
- getStartKey() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getStartKeyForDisplay(RegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
Get the start key for display.
- getStartKeyForDisplay(HRegionInfo, Configuration) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getStartKeyFromName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
get startKey from MobFileName.
- getStartKeys() - Method in interface org.apache.hadoop.hbase.client.AsyncTableRegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartKeysInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getStartLogErrorsCnt() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getStartPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- getStartPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- getStartRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the startrow
- getStartRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns starting row key
- getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the start row.
- getStartRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the start row for a given stripe.
- getStartRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns start row
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getStarts() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getStartTime() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- getStartTime() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getStartTime() - Method in class org.apache.hadoop.hbase.client.RetryingTimeTracker
-
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.Call
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The time when the call starts to be executed.
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getStartTime() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get hbase master start time
- getStartTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Returns the lower bound on timestamps of items of interest
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the task start time.
- getStartTime() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- getStartTimestamp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Gets the time stamp from when the Sink was initialized.
- getStartTrackingTime() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
- getStat() - Method in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- getState() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns table state
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- getState() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getState() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getState() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- getState() - Method in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getState() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getState(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- getState(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
Gets an instance of NamespaceTableAndRegionInfo associated with namespace.
- getState() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Convert an ordinal (or state id) to an Enum (or more descriptive) state object.
- getState() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- getState(int) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getState() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the current state of the task.
- getState() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getStateAndServerName(ZooKeeperProtos.MetaRegionServer) - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getStateColumn() - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column qualifier for serialized table state
- getStateColumn(int) - Static method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getStateId(MasterProcedureProtos.GCMergedRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- getStateId(MasterProcedureProtos.GCMergedRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- getStateId(MasterProcedureProtos.GCRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- getStateId(MasterProcedureProtos.MergeTableRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getStateId(MasterProcedureProtos.MoveRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- getStateId(MasterProcedureProtos.SplitTableRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getStateId(MasterProcedureProtos.RegionStateTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getStateId(MasterProcedureProtos.CloneSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- getStateId(MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getStateId(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getStateId(MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getStateId(MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getStateId(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getStateId(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getStateId(MasterProcedureProtos.InitMetaState) - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- getStateId(MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getStateId(MasterProcedureProtos.ModifyTableDescriptorState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- getStateId(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getStateId(MasterProcedureProtos.RecoverMetaState) - Method in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- getStateId(MasterProcedureProtos.ReopenTableRegionsState) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getStateId(MasterProcedureProtos.RestoreSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- getStateId(MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- getStateId(MasterProcedureProtos.SplitWALState) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getStateId(MasterProcedureProtos.SwitchRpcThrottleState) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- getStateId(MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getStateId(MasterProcedureProtos.PeerModificationState) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- getStateId(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Convert the Enum (or more descriptive) state object to an ordinal (or state id).
- getStateId(MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStateTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getStateToString() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
- getStaticBloomSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns the size of the static blooms for this table
- getStaticBloomSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getStaticIndexSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Returns the size of the static indexes for this table
- getStaticIndexSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getStatisticsAtIndex(int) - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Get statistics at index.
- getStatisticsTracker() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns the current statistics tracker associated with this connection
- getStatisticsTracker() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getStats() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the associated statistics about the region from which this was returned.
- getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- getStats() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Get the statistics for this block cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get a string representation of this sink's metrics
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getStats() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get a string representation of the current statistics for this source
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a string representation of all the sources' metrics
- getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- getStatus() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.Executor
-
- getStatus() - Method in class org.apache.hadoop.hbase.HealthReport
-
Gets the status of the region server.
- getStatus(DataTransferProtos.PipelineAckProto) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- getStatus() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gets the status of this handler; if it is currently servicing an RPC, this status will include
the RPC information.
- getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask.StatusJournalEntry
-
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl.StatusJournalEntryImpl
-
- getStatus() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Returns String of the procedure members both trying to enter the barrier and already in barrier
- getStatus() - Method in interface org.apache.hadoop.hbase.ServerTask
-
Get the current status of the task.
- getStatus() - Method in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- getStatusJournal() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
If journal is enabled, we will store all statuses that have been set along with the time stamps
when they were set.
- getStatusJournal() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
Returns the status journal.
- getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatusTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getStealFromQueue() - Method in class org.apache.hadoop.hbase.util.StealJobQueue
-
Get a queue whose job might be stolen by the consumer of this original queue
- getStopper() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getStopRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns the stoprow
- getStopRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStoragePolicy() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Not using enum
here because HDFS is not using enum
for storage policy, see
org.apache.hadoop.hdfs.server.blockmanagement.BlockStoragePolicySuite for more details.
- getStoragePolicy() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getStoragePolicy() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getStoragePolicyForOldHDFSVersion(Path) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Before Hadoop 2.8.0, there's no getStoragePolicy method for FileSystem interface, and we need
to keep compatible with it.
- getStoragePolicyName(Path) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Get the storage policy of the source path (directory/file).
- getStoragePolicyName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Get the storage policy of the directory of CF.
- getStore() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getStore() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- getStore(Configuration, FileSystem, Path, TableDescriptor, RegionInfo, String) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionWorker
-
- getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStore(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return HStore instance.
- getStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the Store for the given family
- getStoreArchivePath(Configuration, TableName, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Gets the directory to archive a store directory.
- getStoreArchivePathForArchivePath(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getStoreArchivePathForRootDir(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Gets the archive directory under specified root dir.
- getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getStoreCompactionPriority() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns The store compaction priority.
- getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreContext() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of stores
- getStoreCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreDir(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the directory path of the specified family
- getStoreDirHosts(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionInputFormat
-
return the top hosts of the store files, used by the Split
- getStoreEngine() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the StoreEngine that is backing this concrete implementation of Store.
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getStoreFileAgeStream() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreFileComparator() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getStoreFileComparator() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getStoreFileComparator() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreFileCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of storefiles
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStorefileCount() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getStoreFileCount(Region) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- getStorefileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns the number of files currently in use.
- getStorefileCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStorefileFieldSize(HStoreFile, ToLongFunction<StoreFileReader>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- getStoreFileIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
TODO: why we pass the same value to different counters? Currently, the value from
getStoreFileIndexSize() is same with getStoreFileRootLevelIndexSize() see
HRegionServer#createRegionLoad.
- getStoreFileIndexSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Size (in bytes) of indexes in storefiles on disk.
- getStoreFileIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefileIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the total size of store file indexes, in KB
- getStorefileIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreFileInfo(String, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Return the store file information of the specified family/file.
- getStoreFileInfo(Configuration, FileSystem, RegionInfo, RegionInfo, String, Path) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns a StoreFileInfo from the given FileStatus.
- getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStoreFileList(byte[][]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns list of store file names for the given families
- getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Store file manager to use.
- getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStoreFilePath(String, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Return Qualified Path of the specified family/file
- getStoreFileRootLevelIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreFileRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The current total size of root-level indexes for the region
- getStoreFileRootLevelIndexSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreFiles(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns all HFiles belonging to the given region directory.
- getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns Map of StoreFiles by column family
- getStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStoreFiles(String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns All store files.
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the snapshot of the store files currently in use.
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the number of store files
- getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoreFiles(Path) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- getStoreFilesBeingWritten() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Return the storefiles which are currently being written to.
- getStoreFileScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Get a scanner to scan over this StoreFile.
- getStorefilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns Count of store files
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the number of available store files
- getStorefilesFieldSize(ToLongFunction<StoreFileReader>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreFilesFromSnapshot(SnapshotManifest, Predicate<String>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Extracts the names of the store files referenced by this snapshot which satisfy the given
predicate (the predicate returns true
).
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the total size of the storefiles
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreFileSize(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Computes the length of a store file without succumbing to any errors along the way.
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getStoreFileSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the store file size against this table
- getStoreFileSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the total size of store files, in MB
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoreFilesLocatedStatus(HRegionFileSystem, String, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files' LocatedFileStatus which available for the family.
- getStorefilesRootLevelIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesRootLevelIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store file root-level indexes, in bytes.
- getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store files, in bytes.
- getStorefilesSize(Collection<HStoreFile>, Predicate<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns the total size of the store files referenced by the snapshot
- getStoreFileTrackerClassForMigration(Configuration, String) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- getStoreFileTrackerName(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- getStoreFileTrackerName(Class<? extends StoreFileTracker>) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
Returns Gets the cf-specific time-to-live for store files.
- getStoreFileUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreFileUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns The total size of all index blocks, not just the root level
- getStoreFileUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Returns Store flusher to use.
- getStoreHomedir(Path, RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getStoreInfo() - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- getStoreInfo() - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
- getStoreNameForUnderCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
Returns the reference count for the stores of this region
- getStoreRefCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the reference count for the stores of this region
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreRefCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Returns the number of references active on the store
- getStoreRefCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the list of Stores managed by this region
- getStores() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the number of stores
- getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- getStoreSegments() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- getStoreSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getStoreSequenceId() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns completed sequence id per store.
- getStoreSequenceId() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getStoreSizeUncompressed() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreSizeUncompressed() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns The size of the store files, in bytes, uncompressed.
- getStoresRequiringCompaction(Set<String>, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- getStoresRequiringCompaction(TableDescriptor) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
-
- getStoresRequiringCompaction(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- getStoresRequiringCompaction(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- getStoreTracker() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStrategy(Configuration, String, String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
instantiate a strategy from a config property.
- getStream(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Get the stream to use.
- getStream() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Gets the input stream instance.
- getStreamScanner(boolean, boolean, boolean, long, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Get a scanner which uses streaming read.
- getStreamSlowMonitor(String) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
- getStrForMax(int) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getStringCollection(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getStringOrDefault(Bytes, Function<String, T>, T) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getStrings(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getStripeBoundaries() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Returns All stripe boundaries; including the open ones on both ends.
- getStripeBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStripeCompactMaxFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getStripeCompactMinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getStripeCopy(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- getStripeCount() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Returns Stripe count.
- getStripeCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStripeFilesSize(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Gets the total size of all files in the stripe.
- getStripes() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Returns The stripes.
- getStripes() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStub() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getStubKey(String, ServerName) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Get a unique key for the rpc stub to the given server.
- getSubject() - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- getSubject() - Static method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- getSubject() - Static method in class org.apache.hadoop.hbase.thrift2.DemoClient
-
- getSubmittedCounter() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
-
- getSubmittedCounter() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureMetrics
-
Returns Total number of instances submitted for a type of a procedure
- getSubmittedRows() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getSubmittedTime() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getSubprocedureIds() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- getSubproceduresStack() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- getSuccessfulCoalescings() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getSuccessfulCoalescings() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getSuccessfulLogRolls() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- getSuccessfulLogRolls() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- getSuffix(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- getSum(double[]) - Static method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- getSum() - Method in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSummary() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- getSumOfCellElementLengths(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return sum of the lengths of all the elements in a Cell; does not count in any infrastructure
- getSumOfCellKeyElementLengths(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Return sum of all elements that make up a key; does not include infrastructure, tags or values.
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSuperGroups() - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- getSuperSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
Call super-classes' getSplits.
- getSuperUsers() - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- getSupportedAlgorithms() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
Get names of supported compression algorithms.
- getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the set of Ciphers supported by this provider
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Get names of supported compression algorithms.
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getSuspendedProcedures() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
Access to suspendedProcedures is 'synchronized' on this object, but it's fine to return it here
for tests.
- getSweepFuture() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
- getSyncedEntries() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- getSyncedLength() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Returns byteSize success synced to underlying filesystem.
- getSyncedLength() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- getSyncedLength() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- getSyncedLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- getSyncedLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getSyncedLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.WriterBase
-
NOTE: We add this method for
WALFileLengthProvider
used for replication, considering
the case if we use
AsyncFSWAL
,we write to 3 DNs concurrently, according to the
visibility guarantee of HDFS, the data will be available immediately when arriving at DN
since all the DNs will be considered as the last one in pipeline.
- getSyncedPerSec() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- getSyncFuture(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getSyncMetrics() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getSyncWaitMs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- getSyncWaitTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return the blocking wait time for an asynchronous operation.
- getSyncWaitTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getSyncWaitTimeout() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getSystemLoadAverage() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the system load average
- getSystemRegionInfoList() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- getSystemTables(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getSystemUser() - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Retrieve an
AsyncTable
implementation for accessing a table.
- getTable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTable(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getTable() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Get current table name of the region n
- getTable() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns current table name of the region
- getTable(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Gets the table name from the specified region name.
- getTable() - Method in class org.apache.hadoop.hbase.client.replication.TableCFs
-
- getTable() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Get current table name of the region n
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to get the
Table
.
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns table name
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Table
.
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name.
- getTable() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- getTable(String) - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Caller closes the table afterwards.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
Creates and returns a Table instance from a given table name.
- getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- getTable() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTable(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller closes the table afterwards.
- getTableAggregate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Get a MetricsTableAggregateSource
- getTableAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- getTableArchivePath(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableArchivePath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableBuilder(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
- getTableBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getTableBuilder(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.SharedConnection
-
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
Get a TableBuider to build ThriftTable, ThriftTable is NOT thread safe
- getTableCache(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- getTableCF(ReplicationProtos.TableCF[], String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Get TableCF in TableCFs, if not exist, return null.
- getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable (table, cf-list) map of this peer
- getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Get replicable (table, cf-list) map of this peer
- getTableCFsMap() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getTableCFsNode(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- getTableCoprocessorAttrsFromSchema(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.CreateTableFuture
-
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor(TableName, Connection, RpcRetryingCallerFactory, RpcControllerFactory, int, int) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
Returns the table descriptor
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2.TableInfo
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
return TableDescriptor for a given tableName
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns table descriptor for this region
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Returns a table descriptor
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the table descriptor from the Snapshot
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getTableDescriptor(TTableName) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
-
Returns descriptor common to all regions.
- getTableDescriptorFromFs(FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the given table directly from the file system if it
exists, bypassing the local cache.
- getTableDescriptorFromFs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory directly from
the file system if it exists.
- getTableDescriptorFromFs(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptors(MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableDescriptors(List<TableDescriptor>, String, String, List<TableName>, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Return a list of table table descriptors after applying any provided filter parameters.
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of TableDescriptors for requested tables.
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns Return table descriptors implementation.
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getTableDescriptors(List<TTableName>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableDescriptors(List<TableName>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- getTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableDescriptorsByPattern(String, boolean) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns Path
to the region's root directory.
- getTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the Path
object representing the table directory under
path rootdir
- getTableDir(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Return the table directory in HDFS
- getTableDirAndSplitFile(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
nn * @return A Pair where first item is table dir and second is the split file.
- getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableEncodedRegionNameAndLastBarrier(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableEncodedRegionNamesForSerialReplication(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableFamily() - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Returns the column family used for table columns.
- getTableFamily() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column family used for table columns.
- getTableFamilyDescForMeta(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the Table filter regex
- getTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table have more than one
file in them.
- getTableFragmentation(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table have more than one
file in them.
- getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer>, TableName) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Used to get all region locations for the specific table
- getTableHRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
List all region locations for the specific table.
- getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
- getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- getTableInfoFileName(int, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns Name of tableinfo file.
- getTableInfoSequenceIdAndFileLength(Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the current sequence id and file length or 0 if none found.
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified table.
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Return the limiter for the specified table associated with this quota.
- getTableList() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getTableLocations(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
n * @return Map of cached locations for passed tableName
- getTableLock(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- getTableMaxRowSize() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
Returns the table name
- getTableName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTableName() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Get the name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Get the name of the table n
- getTableName() - Method in class org.apache.hadoop.hbase.client.TableState
-
Table name for state n
- getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Get the name of the table n
- getTableName() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Returns table name
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name converted to a byte array.
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- getTableName(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- getTableName() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
Returns the name of the table the procedure is operating on
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableName(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Get the table name from when this cell was written into a mob hfile as a TableName.
- getTableName() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the table the region belongs to.
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getTableName(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getTableName(Region) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getTableName(ByteBuffer) - Static method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getTableName() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the
TableName
object representing the table directory
under path rootdir
- getTableName() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getTableName() - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- getTableName() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns table name
- getTableName() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns table name
- getTableNameAsString() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTableNameAsString() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getTableNameBeforeRestoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check whether the snapshot exists and contains disabled table
- getTableNameFromOp(Row) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
Get table name from Ops such as: get, put, delete.
- getTableNamePrefix() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- getTableNames() - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- getTableNames(MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of userspace table names
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableNamesByPattern(String, boolean) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getTableNamespaceManager() - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
For internals use only.
- getTableNamespaceManager() - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- getTableNamespaceManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getTableNamespaceManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getTableNamespaceManager(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getTableNameString(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the table name from when this cell was written into a mob hfile as a string.
- getTableNameSuffixedWithFamily(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- getTableNamesWithIsTableEnabled() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getTableNameTag(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets the table name tag.
- getTableNode(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
-
Get the zookeeper node associated with archiving the given table
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- getTableOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
Given an operation type we can take decisions about what to do with pending operations.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- getTablePermissions(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- getTablePriority(TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
Return the priority for the given table.
- getTableQueue(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableQuotaCache() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- getTableQuotaSnapshot(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- getTableQuotaSnapshots() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Returns an unmodifiable view over the current
SpaceQuotaSnapshot
objects for each HBase
table with a quota defined.
- getTableQuotaTables() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Returns an unmodifiable view of all tables with table quotas.
- getTableRegionFamilyFiles(Path) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Returns The set of files in the specified family directory.
- getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableRegions(TableName, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getTableRegions() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- getTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Returns the set of the regions contained in the table
- getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Returns the list of regions in the given table, or an empty list if the table does not exist
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer>, TableName, boolean) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Used to get table regions' info and server.
- getTableRegionsAndLocations(TableName, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getTableRegionsAndLocations(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRegionsAndLocations(Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
- getTableRegionsInfo(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getTableRegionStateNodes(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getTableRegionStates(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- getTableRegionStatesCount() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Provide region states count for given table.
- getTableRegionStatesCount() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getTableRegionStatesCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getTableRootPaths(TableName, boolean) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
return paths that user will table permission will visit
- getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTables() - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
Gets the set of table names belonging to namespace.
- getTables() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
Returns the tables
- getTables() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Get set of tables that are members of the group.
- getTables(AtomicInteger) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Return a list of user-space table names whose metadata have not been modified in the last few
milliseconds specified by timelag if any of the REGIONINFO_QUALIFIER, SERVER_QUALIFIER,
STARTCODE_QUALIFIER, SPLITA_QUALIFIER, SPLITB_QUALIFIER have not changed in the last
milliseconds specified by timelag, then the table is a candidate to be returned.
- getTablesByNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
-
Returns a view of all tables that reside in a namespace with a namespace quota, grouped by
the namespace itself.
- getTableSchema() - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- getTableSet() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the table set
- getTablesInStates(TableState.State...) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
Return all tables in given states.
- getTableSize(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the table region size against this table
- getTableSize(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getTableSnapshotPaths(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- getTableSnapshots(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Returns a multimap for all existing table snapshot entries.
- getTableSnapshotStore() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- getTableSource(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getTableSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getTableSourceAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
-
- getTableSpaceUtilization() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Gets the space usage and limit for each table.
- getTableSpaceUtilization() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getTableSplits(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableSplits(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getTableStartRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getTableStartRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns start row for scanning META according to query type
- getTableState(AsyncTable<?>, TableName) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getTableState(Result) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getTableState(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Retrieve TableState, represent current table state.
- getTableState(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getTableState(RpcController, MasterProtos.GetTableStateRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getTableState(RpcController, MasterProtos.GetTableStateRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getTableState() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getTableState(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- getTableState(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table state for given table from META table
- getTableState(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Decode table state from META Result.
- getTableState(ZKWatcher, TableName) - Static method in class org.apache.hadoop.hbase.util.ZKDataMigrator
-
Deprecated.
- getTableStateColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized table state
- getTableStateManager() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- getTableStateManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getTableStateManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableStates(Connection) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Fetch table states from META table
- getTableStopRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
- getTableStopRowForMeta(TableName, MetaTableAccessor.QueryType) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns stop row for scanning META according to query type
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile
names to the full Path.
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, HbckErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, PathFilter, ExecutorService, FSUtils.ProgressReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for table StoreFile
names to the full Path.
- getTableStoreFilePathMap(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to
the full Path.
- getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, HbckErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableStoreFilePathMap(FileSystem, Path, PathFilter, ExecutorService, FSUtils.ProgressReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for table StoreFile names to
the full Path.
- getTableToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regions for tables
- getTableToRegionsByRefCount(Map<ServerName, ServerMetrics>) - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
- getTableUsers(Table, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- getTableWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- getTableWrapperAgg() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
-
- getTag(byte) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTag(Cell, byte) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getTag(byte) - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTag(byte) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTag(Cell, byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Retrieve Cell's first tag, matching the passed in type
- getTag(byte) - Method in interface org.apache.hadoop.hbase.RawCell
-
Returns the specific tag of the given type
- getTag(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a tag by name
- getTagArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getTags() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTags(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getTags() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTags() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTags(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Return tags in the given Cell as a List
- getTags() - Method in interface org.apache.hadoop.hbase.RawCell
-
Creates a list of tags in the current cell
- getTagsArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTagsArray() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Contiguous raw bytes representing tags that may start at any index in the containing array.
- getTagsArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTagsByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTagsLength() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
HBase internally uses 2 bytes to store tags length in Cell.
- getTagsLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the total length of the tag bytes
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTagsOffset() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Returns the first offset where the tags start in the Cell
- getTagsOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the offset where the tag data starts.
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where tag bytes start
- getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTagsPosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTail() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getTailKbParam(HttpServletRequest) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- getTailSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getTakingSnapshotLock() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- getTargetServer() - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- getTargetServerName() - Method in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- getTargetServerName(Result, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the
ServerName
from catalog table
Result
where the region is
transitioning on.
- getTargetState(String, QuotaProtos.SpaceQuota) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- getTargetState(T, QuotaProtos.SpaceQuota) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
- getTargetState(TableName, QuotaProtos.SpaceQuota) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- getTargetToClean() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- getTaskForExecutionCallback - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Callback used by getTasksForAgentCallback while getting command, after getting command
successfully, it executes command and set its status with respect to the command type.
- getTaskList() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getTaskName(long, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- getTaskName(long, String) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- getTaskNode() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getTaskReadySeq() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
Used by unit tests to check how many tasks were processed
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
Returns the number of tasks processed by coordination.
- getTasks() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Gets tasks for execution, basically sets Watch on it's respective host's Znode and waits for
tasks to be assigned, also has a getTasksForAgentCallback which handles execution of task.
- getTasks() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
Returns map of tasks
- getTasks() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- getTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Produces a list containing copies of the current state of all non-expired MonitoredTasks
handled by this TaskMonitor.
- getTasks(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Produces a list containing copies of the current state of all non-expired MonitoredTasks
handled by this TaskMonitor.
- getTasks() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getTasks() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Called directly from clients such as the hbase shell
- getTasks() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getTasksForAgentCallback - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Callback used while getting Tasks for agent if call executed without Exception, It creates a
separate thread for each children to execute given Tasks parallely.
- getTaskType(String) - Static method in enum org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskFilter.TaskType
-
- getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase temp dir.
- getTempDir() - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Gets the temp directory.
- getTempDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns Path
to the region's temp directory, used for file creations
- getter - Static variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- getTerminalPrinter(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- getTerminalPrinter(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- getTerminalSize() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- getTertiaryToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- getTFilterByFromHBase(LogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getThird() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getThread() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
Returns the thread that owned this sync future, use with caution as we return the reference to
the actual thread object.
- getThreadFactory() - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
- getThreadInfo(Thread) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- getThreadPool(int, int, String, BlockingQueue<Runnable>) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getThreadPoolExecutor() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.Executor
-
- getThriftServerType() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getThriftServerType() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- getThriftServerType() - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getThrottlePoint() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- getThrottlePoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Returns ThrottlePoint used for classifying small and large compactions
- getThrottleProto() - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- getThrottleType() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
-
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
-
- getThrowable() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- getThrowable() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- getTHsHaServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getTicket() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getTime() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager.SizeSnapshotWithTimestamp
-
- getTime() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getTimeBetweenRuns() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Return how long in millis has it been since this chore last run.
- getTimeDiffInSec(long) - Static method in class org.apache.hadoop.hbase.util.MoveWithAck
-
- getTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTimeHisto() - Method in class org.apache.hadoop.hbase.metrics.OperationMetrics
-
- getTimeHisto() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureMetrics
-
Returns Histogram of runtimes for all successfully completed instances of a type of a procedure
- getTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- getTimeLimit(RpcCall, HBaseRpcController, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getTimeLimit() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getTimeOfDeath(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Get the time when a server died
- getTimeOfLastRun() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getTimeOfThisRun() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getTimeout(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- getTimeout() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Returns The timeout of this call.
- getTimeout() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- getTimeout() - Method in class org.apache.hadoop.hbase.procedure2.InlineChore
-
- getTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns the timeout in msec
- getTimeout() - Method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedContainerWithTimestamp
-
- getTimeout() - Method in interface org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedWithTimeout
-
- getTimeout(Delayed) - Static method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil
-
- getTimeout() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getTimeoutInterval() - Method in class org.apache.hadoop.hbase.procedure2.InlineChore
-
- getTimeoutInterval() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- getTimeoutTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Timeout of the next timeout.
- getTimeProgress() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Append
-
Gets the TimeRange used for this append.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the time range to check
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's TimeRange n
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
-
Gets the TimeRange used for this increment.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
-
n
- getTimeRange(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getTimeScope() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTimestamp(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
-
Return a long value representing time at which this cell was "Put" into the row.
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Deprecated.
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp.
- getTimestamp() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor.PacketAckData
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the timestamp.
- getTimestamp(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the timestamp.
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTimestamp(long) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getTimeStamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask.StatusJournalEntry
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl.StatusJournalEntryImpl
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowColTSCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getTimestamp() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
Returns the timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTimestamp(String) - Static method in interface org.apache.hadoop.hbase.wal.WAL
-
Split a WAL filename to get a start time.
- getTimestampKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getTimeStampNextToReplicate() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
TimeStamp of next edit to be replicated.
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTimestampOffset(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Timestamp offset
- getTimestampOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the timestamp offset
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTimeStampOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- getTimestampOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the TimestampOfLastAppliedOp.
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Deprecated.
- getTimestampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the timestampsOfLastShippedOp, if there are multiple groups, return the latest one n
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimestampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimeStampOfNextToReplicate() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Returns the list of timestamps
- getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimestampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimestampStarted() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimestampString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getTimeToLive() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Time-to-live of cell contents, in seconds.
- getTimeToLive() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTimeToPurgeDeletes() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- getTimeUnit(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Extracts the time unit for the chore period and initial delay from the configuration.
- getTimeUnit(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Extracts the time unit for the chore period and initial delay from the configuration.
- getTimeUnit(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
Extracts the time unit for the chore period and initial delay from the configuration.
- getTimeUnit(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Extracts the time unit for the chore period and initial delay from the configuration.
- getTimeUnit(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Extracts the time unit for the chore period and initial delay from the configuration.
- getTimeUnit() - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- getTimeUnit() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getTimeUnit() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getTimeUnitInMillis() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getTIOError(IOException) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- gettLogTypeFromHBase(LogQueryFilter) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- getTmpDataDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getTmpDir() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getTmpDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Returns Return the tmp dir this tool writes too.
- getTmpDirName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getTmpNsDir(String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getTmpRecoveredEditsFileName(String) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- getTmpTableDir(TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- getTNonBlockingServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
-
Returns the Token of the specified kind associated with this user, or null if the Token is not
present.
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.provider.AbstractSaslClientAuthenticationProvider
-
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.provider.BuiltInSaslAuthenticationProvider
-
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslAuthenticationProvider
-
- getTokenKind() - Method in interface org.apache.hadoop.hbase.security.provider.SaslAuthenticationProvider
-
Returns the name of the type used by the TokenIdentifier.
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getTokens() - Method in class org.apache.hadoop.hbase.security.User
-
Returns all the tokens stored in the user's credentials.
- getTopBlockLocations(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- getTopBlockLocations(RegionInfo, String) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
Returns an ordered list of hosts which have better locality for this region than the current
host.
- getTopHosts() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Return the sorted list of hosts in terms of their weights
- getTopHostsWithWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Return the sorted list of hosts in terms of their weights
- getToRegion() - Method in class org.apache.hadoop.hbase.master.balancer.SwapRegionsAction
-
- getToServer() - Method in class org.apache.hadoop.hbase.master.balancer.MoveRegionAction
-
- getToServer() - Method in class org.apache.hadoop.hbase.master.balancer.SwapRegionsAction
-
- getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getTotalBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getTotalBufferedCount() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getTotalBufferLimit() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Returns the maximum size in bytes of edits held in memory which are pending replication across
all sources inside this RegionServer.
- getTotalBufferUsed() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- getTotalBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getTotalBytesRead() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the number of bytes read from this stream, since creation.
- getTotalBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of total bytes read from HDFS.
- getTotalBytesRead() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTotalCompactedSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Returns the total data size processed by the currently running compaction, in bytes
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Returns the total compacting key values in currently running compaction
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns The total number of compacting key-values
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalExpectedRegions() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getTotalFailedCount() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- getTotalFailedPutCount() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- getTotalFavoredAssignments() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return the number of regions assigned to their favored nodes
- getTotalFileSize(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- getTotalFiltersCount(AdminProtos.SlowLogResponseRequest) - Static method in class org.apache.hadoop.hbase.namequeues.LogHandlerUtils
-
- getTotalIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getTotalIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getTotalKvCount(Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- getTotalMemory() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
Returns the total memory of the process.
- getTotalNumberOfRacks() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalOpsProcessed() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTotalQueueSize() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getTotalQueueSize() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getTotalRegions() - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total number of requests per second.
- getTotalRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getTotalRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getTotalRequestsCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the total number of requests that have been issued for this table
- getTotalRequestsCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getTotalRITs() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getTotalRITsOverThreshold() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- getTotalRowActionRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getTotalRowActionRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTotalSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getTotalSize(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Get total size of raw cells n * @return Total size.
- getTotalSizeWhenWrittenDelimited(Message...) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
Returns Size on the wire when the two messages are written with writeDelimitedTo
- getTotalSkippedEdits() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- getTotalSleepTime() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter the total time spent in sleep.
- getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the static bloom filters.
- getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total byte size of all Bloom filter bit arrays.
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns The total size of static bloom, in KB
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStaticIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of of the static indexes including the roots.
- getTotalStaticIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total size of all index blocks in the data block indexes, including the root level,
intermediate levels, and the leaf level for multi-level indexes, or just the root level for
single-level indexes.
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns The total size of static index, in KB
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStoreSize(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
Find the total size of a list of store files.
- getTotalSyncedBytes() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- getTotalTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the total overall fragmentation percentage.
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getTotalUncompressedBytes(List<HStoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- getTotalUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The total uncompressed size of the root index block, intermediate-level index blocks, and
leaf-level index blocks.
- getTotalWALSize(FileSystem, List<String>, ServerName) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
return total size in bytes from a list of WALs
- getTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- getTracker() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- getTracker() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- getTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- getTrackerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- getTrackerClass(String) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- getTrackerName() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- getTrackers(RegionCoprocessorHost, NavigableSet<byte[]>, ScanInfo, long, Scan) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getTrailerHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getTrailerHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getTrailerHitCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getTrailerMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getTrailerMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getTrailerMissCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getTrailerSize(int) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTransitionState() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- getTries() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- getTrimmed(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTrimmed(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTrimmedStringCollection(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTrimmedStrings(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTrimmedStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getTrustedChannelResolver(SaslDataTransferClient) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslAdaptor
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getTS(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
-
Split a path to get the start time For example: 10.20.20.171%3A60020.1277499063250 Could also
be a meta WAL which adds a '.meta' suffix or a synchronous replication WAL which adds a
'.syncrep' suffix.
- getTserver() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
the thrift server, not null means the server is started, for test only
- getTThreadedSelectorServer(TNonblockingServerTransport, TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getTThreadPoolServer(TProtocolFactory, TProcessor, TTransportFactory, InetSocketAddress) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Return the TTL requested for the result of the mutation, in milliseconds.
- getTtl() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getTTL() - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTTL() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveMasterLocalStoreHFileCleaner
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveMasterLocalStoreWALCleaner
-
- getTtlMs(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveProcedureWALCleaner
-
Deprecated.
- getTuneDirection(HeapMemoryManager.TunerContext) - Method in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
Determine best direction of tuning base on given context.
- getTxid() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
Returns The transaction id of this edit.
- getTxid() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- getType() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns the tag type
- getType() - Method in class org.apache.hadoop.hbase.ByteBufferTag
-
- getType() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns the type of cell in a human readable format using
Cell.Type
.
- getType() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getType() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getType() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getType() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getType() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- getType() - Method in class org.apache.hadoop.hbase.master.balancer.BalanceAction
-
- getType() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- getType() - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
-
- getType() - Method in interface org.apache.hadoop.hbase.master.normalizer.NormalizationPlan
-
Returns the type of this plan
- getType() - Method in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
-
- getType() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getType() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getType() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getType() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getType() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getType() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- getType() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
Deprecated.
- getType() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns the tag type
- getType() - Method in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTypeByte(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTypeByte(int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getTypeByte() - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Returns The byte representation of the KeyValue.TYPE of this cell: one of Put, Delete, etc
- getTypeByte() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns KeyValue.TYPE byte representation
- getTypeByte(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
Return the KeyValue.TYPE byte representation
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTypeByte(int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the QuotaType types that we want to filter one
- getTypeString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getUGI() - Method in class org.apache.hadoop.hbase.security.User
-
- getUnassignedRegions() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
Return the unassigned regions
- getUnassignMetrics() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Returns
OperationMetrics
containing common metrics for unassign region operation
- getUnassignMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- getUnassignProcMetrics() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
Returns Set of common metrics for unassign procedure
- getUnblockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getUncachedBlockReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getUncachedBlockReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
For testing
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- getUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getUncleanlyClosedWALs() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the value of uncleanlyClosedWAL counter n
- getUncompressedBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- getUncompressedSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
The uncompressed size of the block data, including header size.
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the uncompressed size of data part (header and checksum excluded).
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
The uncompressed size of the block data.
- getUncompressedStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getUncompressedStoreFileSize() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the uncompressed size of the storefiles
- getUncompressedStoreFileSize() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getUndeletedHFileRefsPeers() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
-
- getUnDeletedQueues() - Method in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
-
- getUnderlyingFileLinkInputStream(FSDataInputStream) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
If the passed FSDataInputStream is backed by a FileLink, returns the underlying InputStream for
the resolved link target.
- getUnderlyingInputStream() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- getUnencodedDataSizeWritten() - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
-
- getUnflushedEntriesCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getUnflushedSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
Count the mutations which haven't been flushed
- getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Returns the sum of all unique blocks' weight
- getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
- getUniqueName() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- getUniqueTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- getUnit(String) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- getUnit(String) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getUnit() - Method in class org.apache.hadoop.hbase.Size
-
Returns size unit
- getUnknownServerNames() - Method in interface org.apache.hadoop.hbase.ClusterMetrics
-
Returns the names of region servers on the unknown list
- getUnknownServerNames() - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- getUnknownServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- getUnknownServers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getUnknownServers() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- getUnneededFiles(long, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- getUnneededFiles(long, List<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getUnneededFiles(long, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getUnreferencedFiles(Iterable<FileStatus>, SnapshotManager) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Check to see if any of the passed file names is contained in any of the snapshots.
- getUnwrapKey(Configuration, String, EncryptionProtos.WrappedKey, Cipher) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
- getUpdatesBlockedMsHighWater() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- getUpdatesBlockedTime() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the amount of time that updates were blocked.
- getUpdatesBlockedTime() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getUpdatesLock() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion URL for the root hbase directory.
- getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
Returns the current usage, in bytes, of the target (e.g.
- getUsage() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
-
Returns the current usage, in bytes, of the target (e.g.
- getUsage() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Implementing subclasses should return a usage string to print out.
- getUsedBufferCount() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- getUsedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getUsedHeapSize() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getUsedHeapSize() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the amount of used heap
- getUsedHeapSize() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getUsedSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getUser() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- getUser() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Get the
User
associated with this connection.
- getUser() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- getUser() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- getUser() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
- getUser() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- getUser() - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeTokenIdentifier
-
- getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The user that compiled hbase.
- getUserAggregate() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Return the singleton instance for MetricsUserAggregateSource
- getUserAggregate() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- getUserAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getUserAuths(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getUserAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the user.
- getUserAuthsAsOrdinals(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the user
- getUserAuthsDataToWriteToZooKeeper(Map<String, List<Integer>>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the user auth data to be written to zookeeper.
- getUserEntries(Table, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns the User filter regex
- getUserFromPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getUserFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserGlobalPermission(Configuration, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- getUserGroups(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Retrieve the groups of the given user.
- getUserInfo(User) - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslClientAuthenticationProvider
-
- getUserInfo(User) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslClientAuthenticationProvider
-
- getUserInfo(User) - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- getUserInfo(User) - Method in interface org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProvider
-
Constructs a RPCProtos.UserInformation
from the given UserGroupInformation
- getUserInfo(User) - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslClientAuthenticationProvider
-
- getUserLimiter(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified user/table.
- getUserMetrics() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- getUserMetrics() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns metrics per user
- getUserMetrics() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getUserName() - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- getUserName() - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getUserName() - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Returns Remote client's username.
- getUserName() - Method in class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUserName() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the user name
- getUserName() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- getUsernameFromConf(Configuration) - Static method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
-
Retrieve the static username from the configuration.
- getUserNameFromEncryptionKey(DataEncryptionKey) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- getUserNamespaceAndTable(Table, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- getUserNamespacePermission(Configuration, String, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- getUserNamespacePermissions(Configuration, String, String, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Returns the currently granted permissions for a given namespace as the specified user plus
associated permissions.
- getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the global/namespace/table permissions for user
- getUserPermissions(GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get the global/namespace/table permissions for user
- getUserPermissions(GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- getUserPermissions(GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getUserPermissions(GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getUserPermissions(Connection, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given pattern.
- getUserPermissions(Connection, String, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern and user name.
- getUserPermissions(Connection, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern and column family.
- getUserPermissions(Connection, String, byte[], String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and user name.
- getUserPermissions(Connection, String, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and column
qualifier.
- getUserPermissions(Connection, String, byte[], byte[], String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given table pattern, column family and column
qualifier.
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName, byte[], byte[], String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[], String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- getUserPermissions(Configuration, byte[], byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Returns the currently granted permissions for a given table/namespace with associated
permissions based on the specified column family, column qualifier and user name.
- getUserPermissions(GetUserPermissionsRequest) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- GetUserPermissionsRequest - Class in org.apache.hadoop.hbase.security.access
-
- GetUserPermissionsRequest(String, String, TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.GetUserPermissionsRequest
-
- GetUserPermissionsRequest.Builder - Class in org.apache.hadoop.hbase.security.access
-
- getUserProvider() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuotaCache() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- getUserQuotaState(UserGroupInformation) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the QuotaState associated to the specified user.
- getUserRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserSources() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
- getUserSources() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- getUsersWithGlobalReadAction() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Return users with global read permission
- getUsersWithNamespaceReadAction(String, boolean) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Return users with namespace read permission
- getUsersWithReadAction(ListMultimap<String, UserPermission>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- getUsersWithTableReadAction(TableName, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Return users with table read permission
- getUserTablePermission(Configuration, String, TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- getUserTablePermissions(Configuration, TableName, byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Returns the currently granted permissions for a given table as the specified user plus
associated permissions.
- getUserToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Returns the delegation token acquired, or null in case it was not acquired
- getUseThisHostnameInstead(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getUseThisHostnameInstead(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- getUUIDForCluster(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
Get the UUID for the provided ZK watcher.
- getValByRegex(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- getValidIndex(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
Get the index of the given anchor key for creating subsequent set.
- getValidProcs() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- getValue() - Method in class org.apache.hadoop.hbase.client.CheckAndMutate
-
Returns the expected value
- getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(String) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get a configuration value.
- getValue(Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValue(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue() - Method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- getValue(Bytes) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(byte[]) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(String) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Getter for accessing the metadata associated with the key.
- getValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- getValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
nnn * @return value of type T n
- getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getValue(Bytes) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getValue(Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current value.
- getValue(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
-
- getValue() - Method in interface org.apache.hadoop.hbase.metrics.Gauge
-
- getValue() - Method in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
-
- getValue() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapEntry
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
Returns the value
- getValue() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.COWEntry
-
- getValueArray() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns The byte array backing this Tag.
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getValueArray() - Method in class org.apache.hadoop.hbase.ByteBufferTag
-
- getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getValueArray() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getValueArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the backing array of the entire KeyValue (all KeyValue fields are in a single array)
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- getValueArray() - Method in interface org.apache.hadoop.hbase.Tag
-
Return an array containing the value bytes if
Tag.hasArray()
returns true.
- getValueArray() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getValueAsBigDecimal(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a BigDecimal n * @return value as BigDecimal
- getValueAsByte(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a byte value
- getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueAsDouble(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a double value n * @return value as double
- getValueAsInt(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a int value n * @return value as int
- getValueAsLong(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Converts the value bytes of the given cell into a long value n * @return value as long
- getValueAsLong(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a long value
- getValueAsString(Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Converts the value bytes of the given tag into a String value
- getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns The
ByteBuffer
containing the value bytes.
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.ByteBufferTag
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getValueByteBuffer() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns The
ByteBuffer
containing the value bytes.
- getValueByteBuffer() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getValueCompressionAlgorithm(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- getValueCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getValueCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Returns Value compression algorithm for this log.
- getValueCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- getValueFromMBean(ObjectName, String) - Static method in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- getValueLength() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns Length of actual tag bytes within the backed buffer
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getValueLength() - Method in class org.apache.hadoop.hbase.ByteBufferTag
-
- getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Number of value bytes.
- getValueLength() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getValueLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns Value length
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- getValueLength() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns Length of tag value within the backed buffer
- getValueLength() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.ArrayBackedTag
-
Returns Offset of actual tag bytes within the backed buffer
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.ByteBufferTag
-
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
Returns Array index of first value byte
- getValueOffset() - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns the value offset
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Tag
-
Returns Offset of tag value within the backed buffer
- getValueOffset() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferExtendedCell
-
Returns Position in the
ByteBuffer
where value bytes start
- getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- getValuePosition() - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- getValues() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Get all configuration values.
- getValues() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValues(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- getValues() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Returns Getter for fetching an unmodifiable map.
- getValues() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValues(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Returns Getter for fetching an unmodifiable map.
- getValueShallowCopy() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- getValueShallowCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a shallow copy of the value at the current position.
- getValueShallowCopy() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getValueString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getVaruint64(PositionedByteRange, boolean) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a sequence of bytes in src
as a varuint64.
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this public interface is slightly different from public Java APIs in regard to handling
of the qualifier.
- getVersion() - Method in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Returns the coprocessor environment version
- getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
Returns the Coprocessor interface version
- getVersion() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- getVersion(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
May return "0.0.0" when server is not online
- getVersion() - Method in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- getVersion() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
Returns the storage cluster version
- getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
Returns the object version number
- getVersion() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the string type version of a regionserver.
- getVersion() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- getVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
-
Return the current JVM version information.
- getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the hbase version.
- getVersion() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- getVersionComponents(HBaseProtos.VersionInfo) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Returns the version components Examples: "1.4.3" returns [1, 4, 3], "4.5.6-SNAPSHOT" returns
[4, 5, 6, "SNAPSHOT"]
- getVersionComponents(String) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Returns the version components as String objects Examples: "1.2.3" returns ["1", "2", "3"],
"4.5.6-SNAPSHOT" returns ["4", "5", "6", "-1"] "4.5.6-beta" returns ["4", "5", "6", "-2"],
"4.5.6-alpha" returns ["4", "5", "6", "-3"] "4.5.6-UNKNOW" returns ["4", "5", "6", "-4"]
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
- getVersionedList() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getVersionedTail() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- getVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- getVersionNumber(HBaseProtos.VersionInfo) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
Pack the full number version in a int.
- getVersionNumber(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
May return 0 when server is not online.
- getVersionNumber() - Method in interface org.apache.hadoop.hbase.ServerMetrics
-
Returns the version number of a regionserver.
- getVersionNumber() - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch /version/rest to self.
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling of
the qualifier.
- getViolationPolicy(QuotaProtos.SpaceQuota) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getViolationPolicy() - Method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
Returns the violation policy in effect.
- getVisibilityExpEvaluator(Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getVisibilityExpEvaluator(Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates VisibilityExpEvaluator corresponding to given Authorizations.
- getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
Returns Visibility expression resolver
- getVisibilityLabelService(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getVisibilityLabelService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getVLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getVLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
which is stored as VLong
- getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value, which is stored as VLong, from this range
- getVLongSize(long) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getWaitingProcedures() - Method in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Time in milliseconds to wait for before requesting to consume 'amount' resource.
- getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
Deprecated.
- getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
Returns reference to the region server's WAL
- getWAL() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getWAL() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns WAL in use for this region
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWAL(RegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the WAL for a particular region.
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost.WALEnvironment
-
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- getWAL(String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- getWAL(RegionInfo) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getWAL(RegionInfo) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
- getWalArchiveDir() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getWALArchiveDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Construct the directory name for all old WALs on a given server.
- getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- getWALBlockSize(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Blocksize returned here is 2x the default HDFS blocksize unless explicitly set in
Configuration.
- getWALBlockSize(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Public because of FSHLog.
- getWALCellCodecClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getWALDir() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- getWALDirectoryName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Construct the directory name for all WALs on a given server.
- getWALDirPaths(PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Returns List of all RegionServer WAL dirs; i.e.
- getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
n * @return Gets the walEdit for the operation(Mutation) at the specified position.
- getWALEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getWALEditsRead() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getWALEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getWalEntries() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the WAL Entries.
- getWalEntriesWithSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
Returns the WAL Entries.
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a default set of filters
- getWalEntryFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getWALEntryfilter() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- getWALExcludeDNs() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the excluded datanodes in the cache of this region server.
- getWALExcludeDNs() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getWalFactory() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWalFactory() - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getWALFile() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
-
Deprecated.
Returns full file path in HDFS for the WAL file to be split.
- getWALFile() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getWALFileLengthProvider() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getWALFileLengthProvider() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns the wal file length provider
- getWALFileLengthProvider() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
- getWALFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of WAL files of this region server.
- getWALFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getWALFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getWalFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns the WAL FileSystem
being used by this region
- getWALFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the walFs.
- getWALFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- getWalGroup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- getWalGroupId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getWalGroupsReplicationStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getWalGroupsReplicationStatus() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWalGroupStatus() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getWalGroupStatus() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
get the stat of replication for each wal group.
- getWALNameFromStrPath(String) - Static method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getWalNeedsRoll() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- getWALObserver() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessor
-
- getWalPath() - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- getWALPosition(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getWALPosition(ServerName, String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get the current position for a specific WAL in a given queue for a given regionserver.
- getWALPosition(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getWALPrefixFromWALName(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Get prefix of the log from its name, assuming WAL name in format of
log_prefix.filenumber.log_suffix
- getWALProvider() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getWALReaderEditsBufferBytes() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
Returns the size, in bytes, of edits held in memory to be replicated across all peers.
- getWALReaderEditsBufferBytes() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- getWALReaderEditsBufferUsage() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Returns the amount of memory in bytes used in this RegionServer by edits pending replication.
- getWALRegionDir(MasterProcedureEnv, RegionInfo) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- getWALRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the WAL region directory based on the given table name and region name
- getWalRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWALRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Returns HBase root log dir.
- getWALRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Return the walRootDir.
- getWALRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Get the path for the root directory for WAL data
- getWALs() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWALs() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns the List of WALs that are used by this server Doesn't include the meta WAL
- getWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the normal sources on this rs
- getWALs() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- getWALs() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- getWALs() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- getWALs() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getWALs() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Returns the List of WALs that are used by this server
- getWalsByIdRecoveredQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the recovered sources on this rs
- getWALsInQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- getWALsInQueue(ServerName, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Get a list of all WALs in the given queue on the given region server.
- getWALsInQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getWALsInQueue0(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- getWALSplitDir(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
- getWALsToSplit(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
- getWALTableDir(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Returns the Table directory under the WALRootDir for the specified table name
- getWarmWindowAgeMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getWarmWindowStoragePolicy() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getWarnTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getWarnTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZKListener
-
Returns The watcher associated with this listener
- getWebAppContext() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getWebAppsPath(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the pathname to the webapps files.
- getWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the weight for a specific host, that will be the total bytes of all blocks on the host
- getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the weight
- getWeightedLocality(BalancerClusterState, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCandidateGenerator
-
- getWeightedLocality(int, int) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
- getWeightForSsd() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Returns the weight for ssd
- getWindow(Configuration) - Static method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- getWindowStoragePolicy(long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- getWorker() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- getWorker() - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- getWorkerThreadCount() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Returns the current number of worker threads.
- getWorkingSnapshotDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the general working directory for snapshots - where they are built, where they are
temporarily copied on export, etc.
- getWorkingSnapshotDir(SnapshotProtos.SnapshotDescription, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWorkingSnapshotDir(String, Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWrapper() - Method in class org.apache.hadoop.hbase.io.MetricsIO
-
- getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
-
Provide a size hint to the caller.
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns the number of bytes available to write to avoid exceeding the quota
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getWriteBalancer() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getWriteBufferPeriodicFlushTimeoutMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timeout value in milliseconds.
- getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferPeriodicFlushTimeoutMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteBufferPeriodicFlushTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getWriteBufferPeriodicFlushTimerTickMs() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the current periodic flush timertick interval in milliseconds.
- getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferPeriodicFlushTimerTickMs() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
Returns the maximum size in bytes of the write buffer.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteEntry() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Use it to complete mvcc transaction.
- getWriteFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getWriteFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getWriteFailures() - Method in interface org.apache.hadoop.hbase.tool.Canary
-
- getWriteFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- getWriteFailures() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getWriteFailures() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- getWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- getWriteNumber() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
-
- getWritePoint() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getWriteQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the write queue for metrics when use RWQueueRpcExecutor.
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getWriteQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getWriter() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getWriter() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getWriterClassName() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- getWriterClassName() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- getWriterClassName() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
-
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- getWriterCreationTracker() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.RegionMetrics
-
Returns the number of write requests made to region
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns Current write count for all online regions.
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of mutations that have been issued against this region.
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getWriteRequestCount(String) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
-
Get the number of write requests that have been issued for this table
- getWriteRequestCount(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.UserMetrics
-
Returns the number of write requests made by user
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.UserMetricsImpl
-
- getWriteRequestCountPerSecond() - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of write requests to regions hosted on this region server.
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns write request count for this region
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Returns the current total write requests made to region
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.UserMetrics.ClientMetrics
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- getWriteRequestsRatePerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the rate of write requests per second to regions hosted on this region server.
- getWriteRequestsRatePerSecond() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getWriterFactory(Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers
- getWriterFactoryNoCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers.
- getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Get timeout of each rpc write request in this Table instance.
- getWriteRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getWriteRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- getWriteRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- getWriteRpcTimeout(TimeUnit) - Method in interface org.apache.hadoop.hbase.client.Table
-
Get timeout of each rpc write request in this Table instance.
- getWriteRpcTimeout() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getWriteRpcTimeout(TimeUnit) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- getWriteRpcTimeoutNs() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- getWriteSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- getWriteSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- getWriteTime() - Method in interface org.apache.hadoop.hbase.wal.WALKey
-
Returns the write time
- getWriteTime() - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Returns the write time
- getWrongWALRegionDir(Configuration, TableName, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- getZeroCopyBytesRead() - Static method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getZeroCopyBytesRead() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Returns Number of bytes read locally through HDFS zero copy.
- getZeroCopyBytesRead() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getZk() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- getZKClient() - Method in class org.apache.hadoop.hbase.client.ZKConnectionRegistry
-
- getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getZKPermissionWatcher() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZKPermissionWatcher() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getZkPermissionWatcher() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getZkProcedureUtil() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
Used in testing
- getZKQuorum(Configuration) - Static method in class org.apache.hadoop.hbase.chaos.ChaosUtils
-
- getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration.
- getZKQuorumServersStringFromHbaseConfig(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration n * @return Quorum
servers String
- getZkw() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the ZK connection to this peer
- getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns the znode string corresponding to a replicaId
- getZnodeParent() - Method in class org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
-
- getZNodePaths() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Get the znodePaths.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the key to the ZK ensemble for this configuration without adding a name at the end
- getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Get the key to the ZK ensemble for this configuration and append a name at the end
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the ZooKeeper Quorum Info
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the ZooKeeper Quorum Info
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getZooKeeperServers() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- global() - Static method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Return the global singleton instance for the MetricRegistries.
- GLOBAL - Static variable in class org.apache.hadoop.hbase.metrics.MetricRegistries.LazyHolder
-
- globalArchivePath - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- globalCache - Variable in class org.apache.hadoop.hbase.security.access.AuthManager
-
Cache for global permission excluding superuser and supergroup.
- globalFavoredNodesAssignmentPlan - Variable in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- globalLimiter - Variable in class org.apache.hadoop.hbase.quotas.QuotaState
-
- globalMemStoreDataSize - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStoreHeapSize - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStoreLimit - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStoreLimitLowMark - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStoreLimitLowMarkPercent - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- globalMemStoreLimitLowMarkPercent - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStoreOffHeapSize - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalMemStorePercent - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- globalMemStorePercentMaxRange - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- globalMemStorePercentMaxRange - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- globalMemStorePercentMinRange - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- globalMemStorePercentMinRange - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- GlobalMetricRegistriesAdapter - Class in org.apache.hadoop.hbase.metrics.impl
-
This class acts as an adapter to export the MetricRegistry's in the global registry.
- GlobalMetricRegistriesAdapter() - Constructor for class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
- GlobalMetricRegistriesAdapter.MetricsSourceAdapter - Class in org.apache.hadoop.hbase.metrics.impl
-
- globalMetrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- globalMetricsSource - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- globalOnHeapMemstoreLimit - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- globalOnHeapMemstoreLimitLowMark - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- GlobalPermission - Class in org.apache.hadoop.hbase.security.access
-
Represents an authorization for access whole cluster.
- GlobalPermission(Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.GlobalPermission
-
Construct a global permission.
- GlobalQuotaSettings - Class in org.apache.hadoop.hbase.quotas
-
An object which captures all quotas types (throttle or space) for a subject (user, table, or
namespace).
- GlobalQuotaSettings(String, TableName, String, String) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
-
- GlobalQuotaSettingsImpl - Class in org.apache.hadoop.hbase.quotas
-
- GlobalQuotaSettingsImpl(String, TableName, String, String, QuotaProtos.Quotas) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- GlobalQuotaSettingsImpl(String, TableName, String, String, QuotaProtos.Throttle, Boolean, QuotaProtos.SpaceQuota) - Constructor for class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- globalSourceSource - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- globalStartTime - Variable in class org.apache.hadoop.hbase.client.RetryingTimeTracker
-
- globalWALArchiveDir - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- go - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.EvictionThread
-
- go - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
- goToFilterDisplayMode(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- goToInputModeForFilter(Screen, Terminal, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- goToInputModeForRefreshDelay(Screen, Terminal, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- goToMessageMode(Screen, Terminal, int, String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- grabGlobalCompletelyFreeBucket() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- grabQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- grabQuota(long, long, long, long, long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes the specified write and read amount from the quota.
- grabQuota(long, long, long, long, long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- grabTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
try to grab a 'lock' on the task zk node to own and execute the task.
- grabTaskLock - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Grants user specific permissions
- grant(UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Grants user specific permissions
- grant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- grant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- grant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- grant(RpcController, AccessControlProtos.GrantRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- grant(RpcController, AccessControlProtos.GrantRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- grant(Connection, TableName, String, byte[], byte[], boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified table for the specified user
- grant(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified table for the specified user.
- grant(Connection, String, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified namespace for the specified user.
- grant(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified namespace for the specified user.
- grant(Connection, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grant global permissions for the specified user.
- grant(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grant global permissions for the specified user.
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, boolean, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
Deprecated.
- grant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- grantAcl(UserPermission, Set<String>, Set<TableName>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Set acl when grant user permission
- greater(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
-
- greater(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
-
- GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN Array
- GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN_OR_EQUAL_TO Array
- GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- greaterOrEqual(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
-
- greaterOrEqual(Object) - Method in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
-
- group - Variable in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener
-
- group - Variable in class org.apache.hadoop.hbase.DaemonThreadFactory
-
- group - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
- group - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- group - Variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- group() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- group - Variable in class org.apache.hadoop.hbase.util.NonceKey
-
- group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
-
- group(byte[], byte[]) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider.IdentityGroupingStrategy
-
- group(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
-
Given an identifier and a namespace, pick a group.
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
JobConf parameter to specify the columns used to produce the key passed to collect from the map
phase
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
JobConf parameter to specify the columns used to produce the key passed to collect from the map
phase.
- GROUP_NAME_DELIMITER - Static variable in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
-
- GROUP_PREFIX - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Prefix character to denote group names
- groupAdminServer - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- groupAdminService - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- groupAndSend(Stream<Action>, int) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- groupAndSendMultiAction(List<Action>, int) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Group a list of actions per region servers, and send them.
- groupArchivedFiledBySnapshotAndRecordSize(List<String>, Set<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
For each file in the map, this updates the first snapshot (lexicographic snapshot name) that
references this file.
- groupAuths - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- groupByFamilies(Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- groupCache - Variable in class org.apache.hadoop.hbase.security.UserProvider
-
- groupCall(CompletableFuture<T>, Set<ServerName>, List<RegistryProtos.ClientMetaService.Interface>, int, AbstractRpcBasedConnectionRegistry.Callable<T>, Predicate<T>, String, ConcurrentLinkedQueue<Throwable>) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
send requests concurrently to hedgedReadsFanout end points.
- groupInfoManager - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
-
Extract grouping columns from input record
- GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Extract grouping columns from input record.
- GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
- groupNameCache - Variable in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- groupNames - Variable in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, Table, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Attempt to assign the given load queue item into its target region group.
- groupOrSplitPhase(Table, ExecutorService, Deque<LoadIncrementalHFiles.LoadQueueItem>, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- groups - Variable in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- groups - Static variable in class org.apache.hadoop.hbase.security.UserProvider
-
- groupService - Static variable in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Group service to retrieve the user group information
- grow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- GROW_ALIGN - Static variable in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- growNode(BitSetNode, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Grows node
to contain procId
and updates the map.
- GSON - Static variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- GSON - Static variable in class org.apache.hadoop.hbase.client.BalancerRejection
-
- GSON - Static variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- gson - Variable in class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
-
- GSON - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Needed generating JSON.
- GSON - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- gson - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- GSON - Static variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- GSON - Static variable in class org.apache.hadoop.hbase.util.JSONBean
-
- GSON - Static variable in class org.apache.hadoop.hbase.util.JsonMapper
-
- GSON - Static variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- GsonFactory - Class in org.apache.hadoop.hbase.master.http.gson
-
Provides a singleton Gson
instance configured just the way we like it.
- GsonFactory() - Constructor for class org.apache.hadoop.hbase.master.http.gson.GsonFactory
-
- GsonMessageBodyWriter<T> - Class in org.apache.hadoop.hbase.http.gson
-
Implements JSON serialization via Gson
for JAX-RS.
- GsonMessageBodyWriter(Gson) - Constructor for class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
-
- GsonSerializationFeature - Class in org.apache.hadoop.hbase.master.http.gson
-
Used to register with (shaded) Jersey the presence of Entity serialization using (shaded) Gson.
- GsonSerializationFeature() - Constructor for class org.apache.hadoop.hbase.master.http.gson.GsonSerializationFeature
-
- GsonSerializationFeature.Binder - Class in org.apache.hadoop.hbase.master.http.gson
-
Register this feature's provided functionality and defines their lifetime scopes.
- GsonUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for gson.
- GsonUtil() - Constructor for class org.apache.hadoop.hbase.util.GsonUtil
-
- GssSaslAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
Base client for client/server implementations for the "KERBEROS" HBase auth'n method.
- GssSaslAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.GssSaslAuthenticationProvider
-
- GssSaslClientAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
- GssSaslClientAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- GssSaslServerAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
- GssSaslServerAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.GssSaslServerAuthenticationProvider
-
- GssSaslServerAuthenticationProvider.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security.provider
-
CallbackHandler for SASL GSSAPI Kerberos mechanism
- gt(int, int) - Method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Returns true when lhs > rhs
.
- gtBytes - Static variable in class org.apache.hadoop.hbase.http.HtmlQuoting
-
- guaranteedClientSideOnly - Variable in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- guaranteedClientSideOnly - Variable in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- guess(int) - Method in class org.apache.hadoop.hbase.io.asyncfs.SendBufSizePredictor
-
- GZ_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
-
- GZ_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
-
- GZIP_HEADER - Static variable in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
Fixed ten-byte gzip header.
- GZIP_HEADER_LENGTH - Static variable in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- GzipFilter - Class in org.apache.hadoop.hbase.rest.filter
-
- GzipFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- GZIPRequestStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestStream(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- GZIPRequestWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestWrapper(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- GZIPResponseStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseStream(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- GZIPResponseWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseWrapper(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'I'
- ibmvendor - Static variable in class org.apache.hadoop.hbase.util.JVM
-
- id - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- id(long) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- id - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable
-
- id - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- id - Variable in class org.apache.hadoop.hbase.ClusterId
-
- id - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.Executor
-
- id - Variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- id - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- id - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- id - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
- id - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- id - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- id - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- id - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- id - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- id - Variable in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- id - Variable in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- id - Variable in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- id - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- id - Variable in class org.apache.hadoop.hbase.util.IdLock.Entry
-
- id - Variable in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- id - Variable in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- id2Call - Variable in class org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler
-
- id2Call - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- ID_GEN - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- ID_LENGTH_OFFSET - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- ID_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- idArray - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Maps data block encoding ids to enum instances.
- idealMaxKeys(long, double) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
The maximum number of keys we can put into a Bloom filter of a certain size to maintain the
given error rate, assuming the number of hash functions is chosen optimally and does not even
have to be an integer (hence the "ideal" in the function name).
- idempotentMaskShift(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- identifier - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
- identifier - Variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- identifier - Variable in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- identifier - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- IdentityGroupingStrategy() - Constructor for class org.apache.hadoop.hbase.wal.RegionGroupingProvider.IdentityGroupingStrategy
-
- IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
-
Pass the given key and record as-is to reduce
- IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
constructor
- IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Pass the given key and record as-is to the reduce phase.
- IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
- IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
-
Write to table each key, record pair
- IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
- IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Convenience class that simply writes all values (which must be
Put
or
Delete
instances) passed to it out to the configured HBase table.
- IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
- idInBytes - Variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- IDLE_CONN_SWEEPER - Static variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- IDLE_SERVER_PREDICATOR - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- IDLE_TIME - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- idleRegionServerExist(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- idleScanInterval - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- idleScanThreshold - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- idleScanTimer - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- IdLock - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
- IdLock() - Constructor for class org.apache.hadoop.hbase.util.IdLock
-
- IdLock.Entry - Class in org.apache.hadoop.hbase.util
-
An entry returned to the client as a lock object
- IdReadWriteLock<T> - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
- IdReadWriteLock() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- IdReadWriteLock(IdReadWriteLock.ReferenceType) - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLock
-
Constructor of IdReadWriteLock
- IdReadWriteLock.ReferenceType - Enum in org.apache.hadoop.hbase.util
-
- idSeq - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.
Check for equality.
- ifEquals(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for equality
- ifEquals(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.
Check for equality.
- ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.
Compare a value
- ifMatches(byte[], byte[], CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for match
- ifMatches(Filter) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for match
- ifMatches(CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- ifMatches(CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- ifMatches(CompareOperator, byte[]) - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.
Check for match.
- ifMatches(CompareOperator, byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- ifMissing - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- ifNotExists() - Method in interface org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
-
Deprecated.
Check for lack of column.
- ifNotExists(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
Check for lack of column
- ifNotExists() - Method in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- ifNotExists() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- ifNotExists() - Method in interface org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
-
Deprecated.
Check for lack of column.
- ifNotExists() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- IGNORE_MISSING_FILES - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- IGNORE_TIMESTAMPS - Static variable in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- IGNORE_TIMESTAMPS - Static variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- IGNORE_UNMATCHED_CF_CONF_KEY - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- IGNORE_UNMATCHED_CF_CONF_KEY - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- ignoreCase - Variable in class org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
-
- ignoreCase - Variable in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- ignoreInitialPeriods - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- ignorePreCheckPermission - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- ignoreRegionMoveFailure(ExecutionException) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- ignoreRegionsInTransition - Variable in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
-
- ignoreRegionsInTransition - Variable in class org.apache.hadoop.hbase.client.BalanceRequest
-
- ignoreTimestamp - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- ignoreTimestamps - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- ignoreTimestamps - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- ignoreTimestamps - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- IllegalArgumentIOException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when an illegal argument is passed to a function/procedure.
- IllegalArgumentIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- ImmutableByteArray - Class in org.apache.hadoop.hbase.util
-
Mainly used as keys for HashMap.
- ImmutableByteArray(byte[]) - Constructor for class org.apache.hadoop.hbase.util.ImmutableByteArray
-
- ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
-
A byte sequence that is usable as a key or value.
- ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a zero-size sequence.
- ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a ImmutableBytesWritable using the byte array as the initial value.
- ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the new ImmutableBytesWritable to the contents of the passed ibw
.
- ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the value to a given byte range
- ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
-
A Comparator optimized for ImmutableBytesWritable.
- ImmutableConfWrapper(Configuration) - Constructor for class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- ImmutableHColumnDescriptor - Class in org.apache.hadoop.hbase.client
-
Deprecated.
- ImmutableHColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
-
Deprecated.
- ImmutableHColumnDescriptor(ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHColumnDescriptor
-
Deprecated.
- ImmutableHRegionInfo - Class in org.apache.hadoop.hbase.client
-
Deprecated.
- ImmutableHRegionInfo(RegionInfo) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
Deprecated.
- ImmutableHTableDescriptor - Class in org.apache.hadoop.hbase.client
-
Deprecated.
- ImmutableHTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
Deprecated.
- ImmutableHTableDescriptor(TableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ImmutableHTableDescriptor
-
Deprecated.
- ImmutableMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
-
A MemStoreLAB implementation which wraps N MemStoreLABs.
- ImmutableMemStoreLAB(List<MemStoreLAB>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- ImmutableScan - Class in org.apache.hadoop.hbase.client
-
Immutable version of Scan
- ImmutableScan(Scan) - Constructor for class org.apache.hadoop.hbase.client.ImmutableScan
-
Create Immutable instance of Scan from given Scan object
- ImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
ImmutableSegment is an abstract class that extends the API supported by a
Segment
, and is
not needed for a
MutableSegment
.
- ImmutableSegment(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ Empty C-tor to be used
only for CompositeImmutableSegment
- ImmutableSegment(CellComparator, List<ImmutableSegment>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
- ImmutableSegment(CellSet, CellComparator, MemStoreLAB) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ C-tor to be used to
build the derived classes
- ImmutableSegment(Segment) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
-
------------------------------------------------------------------------ Copy C-tor to be used
when new CSLMImmutableSegment (derived) is being built from a Mutable one.
- impl - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
The coprocessor
- impl - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskAndWeakRefPair
-
- implClassName - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
The class name of the runtime implementation, used as prefix for logging/tracing.
- implementationClassName - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- implementationClassName(String) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Specify a BufferedMutator implementation other than the default.
- implies(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.NamespacePermission
-
check if given action is granted in given namespace.
- implies(Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
check if given action is granted
- implies(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Check if given action can performs on given table:family:qualifier.
- implies(TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Check if given action can performs on given table:family.
- implies(TableName, KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks if this permission grants access to perform the given action on the given table and key
value.
- ImplType - Enum in org.apache.hadoop.hbase.thrift
-
An enum of server implementation selections
- ImplType(String, boolean, Class<? extends TServer>, boolean) - Constructor for enum org.apache.hadoop.hbase.thrift.ImplType
-
- Import - Class in org.apache.hadoop.hbase.mapreduce
-
Import data written by
Export
.
- Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
-
- Import.CellImporter - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that just writes out KeyValues.
- Import.CellReducer - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.CellSortImporter - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.CellWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.CellWritableComparable.CellWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.CellWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- Import.KeyValueImporter - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.KeyValueReducer - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.KeyValueSortImporter - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.KeyValueWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.KeyValueWritableComparable.KeyValueWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
-
- Import.KeyValueWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
-
- IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
-
Tool to import data from a TSV file.
- ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
-
- ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
-
- ImportTsv.TsvParser.ParsedLine - Class in org.apache.hadoop.hbase.mapreduce
-
- in - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- in - Variable in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- in - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- in - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- in - Variable in class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationDeserializer
-
- in - Variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.Result94Deserializer
-
- in - Variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultDeserializer
-
- in - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- IN_MEMORY_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY_COMPACTION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- IN_MEMORY_COMPACTION_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IN_MEMORY_CONPACTION_POOL_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- IN_MEMORY_CONPACTION_POOL_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- IN_MEMORY_FLUSH_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- IN_MEMORY_FLUSH_THRESHOLD_FACTOR_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- inArchive - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
- inArchive() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
Returns true if the file is in the archive
- inBarrierMembers - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- inBuf - Variable in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- inc(byte) - Method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Returns val
incremented by 1.
- INC_BLOCKCACHE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- INC_BLOCKCACHE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- INC_MEMSTORE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- INC_MEMSTORE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- incActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Increment number of active thrift workers.
- incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incActiveWorkerCount() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- incBlockCacheSizeHistogram - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- incCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a call took
- incCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incChildrenLatch() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor on procedure-load to restore the latch state
- incCounters(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a counter.
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Increment a named counter by some value.
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incFailuresCountDetails(ServerName, RegionInfo) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- incGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a gauge.
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Add some amount to a gauge.
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incGlobalMemStoreSize(MemStoreSize) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- incGlobalMemStoreSize(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- incInfoThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Increment the INFO level threshold exceeded count
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incInfoThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- include(RegionStateNode, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Utility.
- INCLUDE_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
If query string includes 'description', then we will emit bean and attribute descriptions to
output IFF they are not null and IFF the description is not the same as the attribute name:
i.e.
- IncludeAllCompactionQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A compaction query matcher that always return INCLUDE and drops nothing.
- IncludeAllCompactionQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
-
- includeDeletedCells - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- includeExcludeRegionServers(String, List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Designates or excludes the servername whose hostname and port portion matches the list given in
the file.
- includeMVCCReadpoint - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- includeMVCCReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether to include MVCC or not
- includeNextStartRowWhenError - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Test if the given region is to be included in the InputSplit while splitting the regions of a
table.
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Test if the given region is to be included in the InputSplit while splitting the regions of a
table.
- includesMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- includesMvcc() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
-
- includesMvcc - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Whether mvcc is to be included in the Read/Write
- includesMvcc - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Whether mvcc is to be included in the Read/Write
- includesTag - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- includesTag() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- includesTag(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether to includesTag or not
- includesTags() - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
-
- includesTags - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Whether tags are to be included in the Read/Write
- includesTags - Variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
Whether tags are to be included in the Read/Write
- includeStartRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- includeStartRow - Variable in class org.apache.hadoop.hbase.client.Scan
-
- includeStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns if we should include start row when scan
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the range has any overlap with TimeRange
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Check if the range has ANY overlap with TimeRange
- includeStopRow() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- includeStopRow - Variable in class org.apache.hadoop.hbase.client.Scan
-
- includeStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns if we should include stop row when scan
- includeStopRow - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- includeTags - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- includeTimestamp(Cell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from cell
.
- includeTimestamp(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
If required, update the current TimestampRange to include timestamp
- InclusiveCombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- InclusiveCombinedBlockCache(FirstLevelBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Updates the heap size counter of the segment by the given delta
- incMemStoreSize(MemStoreSize) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Increase the size of mem store in this region and the size of global mem store
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- incMemStoreSize(long, long, long, int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
Returns The new dataSize ONLY as a convenience
- incMemStoreSize(MemStoreSize) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.NonThreadSafeMemStoreSizing
-
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- incMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.ThreadSafeMemStoreSizing
-
- incMemStoreSizeHistogram - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- incMethodTime(String, long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a method took
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incMySeqNum() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- incNextCallSeq(long) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- incNumRowKeysInBatchGet(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch get.
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incNumRowKeysInBatchMutate(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch mutate.
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate a filter incompatibility
- IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- INCONSISTENT_ARCHIVE_BAD_LINK - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- INCONSISTENT_ARCHIVE_IOE - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- INCONSISTENT_ARCHIVE_STALE - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- INCONSISTENT_REGIONS - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- INCONSISTENT_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- inconsistentRegions - Variable in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- inconsistentRegionsGauge - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- incPeerSeqNum() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- incr() - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
- incr(long) - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
Increment the value by a delta
- incrAppliedBatches(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrAppliedBatches(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrAppliedHFiles(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrAppliedHFiles(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrAppliedOps(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrAppliedOps(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrBatchesShipped(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrBytesSkippedInUncleanlyClosedWALs(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrCacheDroppingExceptions(Object) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrCompletedRecoveryQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrCompletedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrDelayRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
-
- incrDelayRunnersAndUpdateDelayInterval(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of delay runner counts and update delay interval of delay runner.
- incReadFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- incReadFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- incReadSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- incReadSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Increase the counter for heap occupancy percent above low watermark
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Increase the counter for heap occupancy percent above low watermark
- increaseAboveHeapOccupancyLowWatermarkCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- increaseTunerDoNothingCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Increase the counter for tuner neither expanding memstore global size limit nor expanding
blockcache max size.
- increaseTunerDoNothingCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Increase the counter for tuner neither expanding memstore global size limit nor expanding
blockcache max size.
- increaseTunerDoNothingCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- IncreasingToUpperBoundRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
Split size is the number of regions that are on this server that all are of the same table,
cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
- IncreasingToUpperBoundRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- incRegionCountForTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
- incRegionCountMetrics(ScanMetrics) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- increment(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- increment(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
-
- Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Copy constructor
- Increment(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Construct the Increment with user defined data.
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
-
Increments one or more columns within a single row.
- increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
nn
- increment() - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Increment this
by 1.
- increment(long) - Method in interface org.apache.hadoop.hbase.metrics.Counter
-
Increment this
by n
.
- increment() - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
-
- increment(long) - Method in class org.apache.hadoop.hbase.metrics.impl.CounterImpl
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Increment the current version count
- increment(Increment) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more increment operations on a row.
- increment(HRegion, OperationQuota, ClientProtos.MutationProto, CellScanner, long, ActivePolicyEnforcement) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Execute an increment mutation.
- increment(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
Validates the input request parameters, parses columns from CellSetModel, and invokes Increment
on HTable.
- increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- increment() - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- INCREMENT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- incrementAndGetRetries() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- incrementAppendCount(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the count of wal appends
- incrementAppendCount(TableName) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementAppendSize(TableName, long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the append size.
- incrementAppendSize(TableName, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementAppendTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to append.
- incrementAppendTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementAuthFailedCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to AUTHFAILED Exception.
- incrementAuthFailedCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- incrementBatchProgress(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Progress towards the batch limit has been made.
- incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Bytewise binary increment/deincrement of long contained in byte array on given amount.
- incrementClientReadMetrics(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- incrementClientWriteMetrics(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- IncrementCoalescer - Class in org.apache.hadoop.hbase.thrift
-
This class will coalesce increments from a thift server if
hbase.regionserver.thrift.coalesceIncrement is set to true.
- IncrementCoalescer(ThriftHBaseServiceHandler) - Constructor for class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- IncrementCoalescer.FullyQualifiedRow - Class in org.apache.hadoop.hbase.thrift
-
Used to identify a cell that will be incremented.
- IncrementCoalescerMBean - Interface in org.apache.hadoop.hbase.thrift
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.Table
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically increments a column value.
- incrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- incrementConnectionLossCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a CONNECTIONLOSS Exception.
- incrementConnectionLossCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementCountOfRowsFilteredMetric(ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- incrementCountOfRowsScannedMetric(ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- incrementDataInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a DATAINCONSISTENCY Exception.
- incrementDataInconsistencyCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementEdits(int) - Method in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- incrementEligible() - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Increment for cases where bloom filter could have been used but wasn't defined or loaded.
- incrementErrorLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementErrorLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed append requests.
- incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Convenience method to update metrics when batch of operations has failed.
- incrementFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Convenience method to update metrics when batch of operations has failed.
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Delete requests.
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Get requests.
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed increment requests.
- incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Put Requests.
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed scan requests.
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFilteredReadRequests(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- incrementFilteredReadRequests() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- incrementFilteredReadRequests() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- incrementFlushesQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- incrementFromHBase(Increment) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- incrementHeapSize(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- incrementHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrementHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- IncrementingEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
Uses an incrementing algorithm instead of the default.
- IncrementingEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Construct an incremental edge starting from currentTimeMillis
- IncrementingEnvironmentEdge(long) - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Construct an incremental edge with an initial amount
- incrementInvalidACLCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to INVALIDACL Exception.
- incrementInvalidACLCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- incrementIv(int) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec.EncryptedKvEncoder
-
- incrementKBsCounter(MutableFastCounter, MutableFastCounter) - Static method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrementLogRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementLowReplicationLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementLowReplicationLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementNanoTime(long) - Method in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- incrementNbHFiles(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- incrementNbRowKeys(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- incrementNoAuthCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to NOAUTH Exception.
- incrementNoAuthCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementNumOfAppends() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- incrementNumOfDeletes() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- incrementNumOfIncrements() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- incrementNumOfPuts() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- incrementNumRegionSizeReportsSent(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrementNumRegionSizeReportsSent(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how many region size reports were sent from this RegionServer to
the Master.
- incrementNumRegionSizeReportsSent(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- incrementOperationCounter() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- incrementOperationCounter() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
TODO: Remove.
- incrementOperationCounter() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- incrementOperationTimeoutCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to an OPERATIONTIMEOUT Exception.
- incrementOperationTimeoutCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementQuotaObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time of a period of the QuotaObserverChore.
- incrementReadRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- incrementReadRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- incrementRefCount() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Indicate that the scanner has started reading with this reader.
- incrementRegionSize(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- incrementRegionSize(RegionInfo, long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Atomically alter the size of a region.
- incrementRegionSize(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- incrementRegionSizeReportingChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrementRegionSizeReportingChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent sending region size reports to the Master
by the RegionSizeReportingChore.
- incrementRegionSizeReportingChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- incrementRequests(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
Increment bloom request count, and negative result count if !passed
- incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of requests
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementResponseBlockSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- incrementResponseBlockSize(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- incrementResponseCellSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Add on the given amount to the retained cell size.
- incrementResponseCellSize(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- incrementResponseExceptionSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- incrementResponseExceptionSize(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- incrementRuntimeInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to RUNTIMEINCONSISTENCY Exception.
- incrementRuntimeInconsistencyCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementSessionExpiredCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a SESSIONEXPIRED Exception.
- incrementSessionExpiredCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementSize(long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Atomically adds the provided delta
to the region size.
- incrementSize(long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
-
- incrementSizeLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementSizeLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSizeProgress(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Progress towards the size limit has been made.
- incrementSkippedEdits(int) - Method in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- incrementSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the number of appends that were slow
- incrementSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSlowSyncLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementSlowSyncLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSnapshotFetchTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time to fetch the mapping of snapshots to originating table.
- incrementSnapshotObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore
which runs periodically.
- incrementSnapshotObserverChoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- incrementSnapshotObserverSnapshotComputationTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore
to compute the size of one snapshot, relative to the files referenced by the originating table.
- incrementSnapshotObserverSnapshotComputationTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- incrementSnapshotObserverSnapshotFetchTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore
to fetch all snapshots.
- incrementSnapshotObserverSnapshotFetchTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- incrementSnapshotObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time of a period of the SnapshotQuotaObserverChore
.
- incrementSnapshotSizeComputationTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the execution time to compute the size of a single snapshot.
- incrementSpaceQuotaFileSystemScannerChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent scanning the filesystem to compute the size
of each region hosted by this RegionServer.
- incrementSpaceQuotaFileSystemScannerChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- incrementSpaceQuotaObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
Updates the metric tracking the amount of time taken by the QuotaObserverChore
which
runs periodically.
- incrementSpaceQuotaObserverChoreTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- incrementSpaceQuotaRefresherChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
Updates the metric tracking how much time was spent updating the RegionServer with the latest
information on space quotas from the hbase:quota
table.
- incrementSpaceQuotaRefresherChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- incrementSuccessfulLogRolls() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the number of successful log roll requests.
- incrementSuccessfulLogRolls() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful append requests.
- incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Delete requests.
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Get requests.
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful increment requests.
- incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Put requests.
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful scan requests.
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to sync the wal.
- incrementSyncTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSystemErrorCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Increment the count of failed ops due to a SYSTEMERROR Exception.
- incrementSystemErrorCount() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementTime(long) - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Increment the time by the given amount
- incrementTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- incrementTotalFailedZKCalls() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the total number of failed ZooKeeper API calls.
- incrementTotalFailedZKCalls() - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- incrementTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- incrementUgiReference(UserGroupInformation) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- incrementWriteRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
-
- incrementWriteRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- incrementWrittenBytes(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementWrittenBytes(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Increment the number of requests the cluster has seen.
- incRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- incrFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrFailedBatches() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrFailedBatches() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrFailedBatches() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrFailedRecoveryQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrFailedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrHedgedReadOps() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of hedged read that have occurred.
- incrHedgedReadWin() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of hedged read returned faster than the original read.
- incrHFilesShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrHFilesShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrHFilesShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrLogEditsFiltered(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Add on the number of log edits filtered
- incrLogEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
The number of log edits filtered out.
- incrLogEditsRead(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Add on the the number of log edits read
- incrLogEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Increment the number of log edits read by one.
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrLogReadInBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
increase the byte number read by source from log file
- incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrLogReadInEdits(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrMetaCacheHit() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache hits.
- incrMetaCacheMiss() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache misses.
- incrMetaCacheNumClearRegion() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for individual region.
- incrMetaCacheNumClearRegion(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for individual region.
- incrMetaCacheNumClearServer() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of meta cache drops requested for entire RegionServer.
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- incrMiscInvocations() - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
-
- incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
Increment the number of normal runner counts.
- incrNormalRunners() - Method in class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
-
- incrNsLookups() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- incrNsLookupsFailed() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrOpsShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incRPCCallsMetrics(ScanMetrics, boolean) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- incRPCRetriesMetrics(ScanMetrics, boolean) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrRepeatedFileBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrRestartedWALReading() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrScannerLeaseExpired() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrScannerLeaseExpired() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- incrScannerLeaseExpired() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrShippedBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrShippedBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrShippedBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrShippedBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSource
-
- incrShippedBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrSizeOfHFileRefsQueue(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Increment size of the log queue.
- incrSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Appends that have happened.
- incrSlowAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Deletes that have happened.
- incrSlowDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Gets that have happened.
- incrSlowGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Increments that have happened.
- incrSlowIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowPut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Puts that have happened.
- incrSlowPut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrSourceInitializing() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrSourceInitializing() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Increment the count for initializing sources
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of a requested splits
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSplitRequest(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
-
- incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Increment number of a requested splits
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of successful splits
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSplitSuccess(String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTable
-
- incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
Increment number of successful splits
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrUncleanlyClosedWALs() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- incrUnknownFileLengthForClosedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- incSlowCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Increment how long a slow call took.
- incSlowCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incTaskCounters(Collection<byte[]>, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- incTaskCounters(Collection<byte[]>, ServerName) - Method in interface org.apache.hadoop.hbase.client.RequestController
-
Increment the counter if we build a valid task.
- incTaskCounters(Collection<byte[]>, ServerName) - Method in class org.apache.hadoop.hbase.client.SimpleRequestController
-
- incTimeInQueue(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long an operation was in the queue.
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- incWarnThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
Increment the WARN level threshold exceeded count
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incWarnThresholdExceeded(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incWriteFailureCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- incWriteFailureCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- incWriteSuccessCount() - Method in interface org.apache.hadoop.hbase.tool.CanaryTool.Sink
-
- incWriteSuccessCount() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- index - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- index - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCachesIterator
-
- index - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- index - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapIterator
-
- index - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- index - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- index - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntryIterator
-
- index - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeyIterator
-
- index - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueIterator
-
- index(long) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- INDEX_CHUNK_SIZE_PERCENTAGE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- INDEX_CHUNK_SIZE_PERCENTAGE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- INDEX_CHUNK_UNUSED_SPACE_PRECENTAGE - Static variable in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- INDEX_COLUMN - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the column family containing the indexed row key
- INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
- INDEX_QUALIFIER - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the qualifier containing the indexed row key
- indexBlockElements - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Current number of cached index block elements
- indexBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Current size of index blocks
- IndexBuilder - Class in org.apache.hadoop.hbase.mapreduce
-
Example map/reduce job to construct index tables that can be used to quickly find a row based on
the value of a column.
- IndexBuilder() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
- IndexBuilder.Map - Class in org.apache.hadoop.hbase.mapreduce
-
Internal Mapper to be run by Hadoop.
- indexChunkSize - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- indexChunksPool - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
-
- indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- indexes - Variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
-
- indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the index of the first appearance of the value target
in array
.
- indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the start position of the first occurrence of the specified target
within array
, or -1
if there is no such occurrence.
- indexOf(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- IndexOnlyLruBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
An on heap block cache implementation extended LruBlockCache and only cache index block.
- IndexOnlyLruBlockCache(long, long, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
-
- indexSize() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- indexSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- indexSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- IndexStatistics(long, long, long, int, int, long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
- IndexStatistics() - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
- indexToNode - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- indexType - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- IndexType() - Constructor for enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
-
- indexWithinComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- IndividualBytesFieldCell - Class in org.apache.hadoop.hbase
-
- IndividualBytesFieldCell(byte[], byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- IndividualBytesFieldCell(byte[], byte[], byte[], long, KeyValue.Type, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- IndividualBytesFieldCell(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, long, byte[], int, int, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- IndividualBytesFieldCellBuilder - Class in org.apache.hadoop.hbase
-
- IndividualBytesFieldCellBuilder() - Constructor for class org.apache.hadoop.hbase.IndividualBytesFieldCellBuilder
-
- inetSocketAddress2String(InetSocketAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Given an InetSocketAddress object returns a String represent of it.
- inFastFailMode(ServerName) - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
Checks to see if we are in the Fast fail mode for requests to the server.
- inferBoundaries(SortedMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Infers region boundaries for a new table.
- inferMimeType(ServletRequest) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
Infer the mime type for the response based on the extension of the request URI.
- inflightWALClosures - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Tracks the logs in the process of being closed.
- info - Variable in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- info(String, String) - Static method in class org.apache.hadoop.hbase.metrics.Interns
-
Get a metric info object
- info() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Returns the info object of the metrics registry
- INFO_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- INFO_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- INFO_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- INFO_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- infoCache - Static variable in class org.apache.hadoop.hbase.metrics.Interns
-
- infoPauseThresholdExceeded - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- infoPauseThresholdExceeded - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- infoPauseThresholdExceeded - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- infoPort - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- INFOPORT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- infos - Static variable in class org.apache.hadoop.hbase.security.SecurityInfo
-
Maps RPC service names to authentication information
- InfoServer - Class in org.apache.hadoop.hbase.http
-
Create a Jetty embedded server to answer http requests.
- InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.InfoServer
-
Create a status server on the given port.
- infoServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- infoServer - Variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- infoServer - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- infoServerPort - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- infoServerPort - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- infoThresholdMs - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
log INFO if we detect a pause longer than this threshold
- INFRASTRUCTURE_SIZE - Static variable in interface org.apache.hadoop.hbase.Tag
-
- inGlobalBarrier - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
wait on before allowing the in barrier phase to proceed
- init() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Support method to init constants such as timeout.
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
Initialize internal values.
- init() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- init() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- init() - Method in interface org.apache.hadoop.hbase.hbtop.screen.ScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- init() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- init(String, long) - Method in class org.apache.hadoop.hbase.HealthChecker
-
Initialize.
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Initialize this servlet.
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.SecurityHeadersFilter
-
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Initialize the key provider n
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- init() - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- init(int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
- init(int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Does some quick initialization.
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- init(RegionLocator, Admin) - Method in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
- init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Giving a chance for the initialization.
- init() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
- init(Map<String, Object>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
this method is used to pass some instance into subclass
- init() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.slowlog.SlowLogMasterService
-
- init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- init() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Clear out the metrics and re-prepare the source.
- init(String) - Method in enum org.apache.hadoop.hbase.metrics.BaseSourceImpl.DefaultMetricsSystemInitializer
-
- init() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- init() - Static method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
Make sure that this global MetricSource for hbase-metrics module based metrics are initialized.
- init(byte[], HRegionServer) - Method in class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
-
- init(int, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Initialize the procedure executor, but do not start workers.
- init(byte[], HRegionServer) - Method in interface org.apache.hadoop.hbase.procedure2.RSProcedureCallable
-
Initialize the callable
- init(Configuration, Scan) - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- init(Connection, Scan) - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- init(StoreScanner, AbstractMultiFileWriter.WriterFactory) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Initializes multi-writer before usage.
- init() - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- init() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
Actually claim the memory for this chunk.
- init(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- init() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Used to initialize the WAL.
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueueStorage, ReplicationPeer, Server, String, UUID, WALFileLengthProvider, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueueStorage, ReplicationPeer, Server, String, UUID, WALFileLengthProvider, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Instantiation method used by region servers
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueueStorage, ReplicationPeer, Server, String, UUID, WALFileLengthProvider, MetricsSource) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Initializer for the source
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Adds a normal source per registered peer cluster.
- init(Connection) - Method in interface org.apache.hadoop.hbase.replication.regionserver.WALEntrySinkFilter
-
Called after Construction.
- init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initialize the replication endpoint with the given context.
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- init() - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- init(Configuration, ServiceAuthorizationManager) - Static method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- init(Configuration) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- init(Configuration) - Method in interface org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider
-
Allows implementations to initialize themselves, prior to creating a server.
- init(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- init(RegionCoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System calls this after opening of regions.
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- init() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- init(Path, String, Configuration) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- init(WALFactory, Configuration, String, Abortable) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in interface org.apache.hadoop.hbase.wal.AbstractFSWALProvider.Reader
-
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in interface org.apache.hadoop.hbase.wal.AsyncFSWALProvider.AsyncWriter
-
- init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
-
- init(WALFactory, Configuration, String, Abortable) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- init(FileSystem, Path, Configuration, boolean, long, StreamSlowMonitor) - Method in interface org.apache.hadoop.hbase.wal.FSHLogProvider.Writer
-
- init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
-
- init(Configuration, String) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider.IdentityGroupingStrategy
-
- init(WALFactory, Configuration, String, Abortable) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- init(Configuration, String) - Method in interface org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
-
- init(byte[], TableName, long, long, List<UUID>, long, long, MultiVersionConcurrencyControl, NavigableMap<byte[], Integer>, Map<String, byte[]>) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- init(WALFactory, Configuration, String, Abortable) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Set up the provider to create wals.
- INIT_ERROR_EXIT_CODE - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- initAdmin() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- initAfterHeader0(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- initAndStartReplicationEndpoint(ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- initBlockCache() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- initByteBufferPositionReadableMethod() - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
- initByteBuffToReadInto(int) - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- initCache() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- initCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- initCellFilters() - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- initChaosAgent(Configuration, String, String) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
sets global params and initiates connection with ZooKeeper then does registration.
- initCleanerChain(String) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Instantiate and initialize all the file cleaners set in the configuration
- initClusterSchemaService() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- initCopyTableMapperReducerJob(Job, Scan) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- initCosts(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Obtain an authentication token, for the specified cluster, on behalf of the current user and
add it to the credentials for the given map reduce job.
- initCredentialsForHBase(String, Job) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- initCryptoCipher(RPCProtos.CryptoCipherMeta, Configuration) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- inited - Variable in enum org.apache.hadoop.hbase.metrics.BaseSourceImpl.DefaultMetricsSystemInitializer
-
- initError - Variable in class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
-
- initFieldDisplayMapAndFieldLengthMap(List<Field>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.FilterInitializer
-
Initialize a Filter to a FilterContainer.
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
-
- initGroupService(Configuration) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- initHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- initHFileInfo(ReaderContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- INITIAL_CELLSCANNER_INDEX - Static variable in class org.apache.hadoop.hbase.client.Result
-
- INITIAL_KEY_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
TODO: This datablockencoder is dealing in internals of hfileblocks.
- INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
-
- INITIAL_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.io.TimeRange
-
- INITIAL_MIN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- INITIAL_REFRESH_DELAY_SECS - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
As end users could configure any nodes in a cluster as the initial bootstrap nodes, it is
possible that different end users will configure the same machine which makes the machine over
load.
- INITIAL_STRIPE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The initial stripe count to create.
- initialActions - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
- initialChore() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- initialChore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run a task before we start looping.
- initialChoreComplete - Variable in class org.apache.hadoop.hbase.ScheduledChore
-
- initialCompactionProbability - Variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- initialCount - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- initialDelay - Variable in class org.apache.hadoop.hbase.ScheduledChore
-
- initialDelayMs - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- initialEncodedRegionName - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable
-
- initialFilters - Variable in class org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
-
- initialFunctionCosts - Variable in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- initialFunctionCosts - Variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- INITIALIZATION_ERROR - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- INITIALIZATION_ERROR - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- initialize(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- initialize(P) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should initialize any field(s) of the ColumnInterpreter with a parsing of the
passed message bytes (used on the server side).
- initialize() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- initialize() - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- initialize(SnapshotOfRegionAssignmentFromMeta) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- initialize(boolean) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- initialize(Configuration, Channel, DatanodeInfo, StorageType, DataTransferProtos.OpWriteBlockProto.Builder, int, DFSClient, Token<BlockTokenIdentifier>, Promise<Channel>) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- initialize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- initialize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- initialize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Handle subclass specific set up.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Handle subclass specific set up.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Initializes the reader.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Build the scanner.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- initialize(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Initialize the load balancer.
- initialize(TableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Initialize the region assignment snapshot by scanning the hbase:meta table
- initialize() - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
Initialize namespace state cache by scanning meta table.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Initialize this region server flush procedure manager Uses a zookeeper based member controller.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Initialize a globally barriered procedure for master.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Initialize a globally barriered procedure for region servers.
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- initialize(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- initialize(Connection) - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier
-
Initializes the notifier.
- initialize(RegionServerServices, TableName, SpaceQuotaSnapshot) - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Initializes this policy instance.
- initialize(Connection) - Method in class org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
-
- initialize(int, boolean, long, float, float, HeapMemoryManager, float) - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
Initializes the instance of ChunkCreator
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
-
- initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- initialize(CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Initialize this region.
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
-
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
-
- initialize(TableDescriptor, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
Initialize the RegionSplitRestriction instance
- initialize(Server, FileSystem, Path, Path, WALFactory) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Initializes the replication service object.
- initialize(S) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
This method should initialize any field(s) of the RowProcessor with a parsing of the passed
message bytes (used on the server side).
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Create a default snapshot handler - uses a zookeeper based member controller.
- initialize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- initialize(Server, FileSystem, Path, Path, WALFactory) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- initialize() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- initialize(Server, FileSystem, Path, Path, WALFactory) - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- initialize(Cluster, Configuration, boolean, Optional<KeyStore>) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- initialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- initialize(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- initialize(Configuration) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Should be called only once to pre-load list of super users and super groups from Configuration.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- initialize() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- initializeAndGetReadLatencyForTable(String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- initializeCellSet(int, MemStoreSegmentsIterator, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
- initializeCellSet(int, MemStoreSegmentsIterator, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- initializeChildren(RootProcedureState<TEnvironment>, Procedure<TEnvironment>, Procedure<TEnvironment>[]) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- initializeCompressionContext(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- initializeCoprocessorHost(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- initialized - Variable in class org.apache.hadoop.hbase.filter.FuzzyRowFilter.RowTracker
-
- initialized - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- initialized - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- initialized - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- initialized - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- initialized - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- initialized - Variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- initialized - Variable in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- initialized - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- initialized - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if we have been successfully initialized
- initialized - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- initialized - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- initialized - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- initialized - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- initialized - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- INITIALIZED_FLAG - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- initializeFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- initializeKVHeap(List<KeyValueScanner>, List<KeyValueScanner>, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- initializeKVHeap(List<KeyValueScanner>, List<KeyValueScanner>, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ReversedRegionScannerImpl
-
- initializeMemStoreChunkCreator() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- initializePool(int, String) - Static method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- initializePool(String, long, float, float, int, ChunkCreator.ChunkType, HeapMemoryManager) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- initializePools(int, long, float, float, float, HeapMemoryManager) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- initializeQueues(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- initializeRegionInternals(CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- initializeRegionSizes() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- initializeScanners(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- initializeSnapshotStores(Map<RegionInfo, Long>) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- initializeStoreContext(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- InitializeStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Procedure for setting StoreFileTracker information to table descriptor.
- InitializeStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
-
- InitializeStoreFileTrackerProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
-
- initializeStores(CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Open all Stores.
- initializeStores(CancelableProgressable, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initializeThreads() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- initializeWALEntryFilter(UUID) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- initializeWarmup(CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- initializeWebServer(String, String, Configuration, String[], HttpServer.Builder) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- initializeWorkQueues() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- initializeWriteLatency() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- initializeZKBasedSystemTrackers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Initialize all ZK based system trackers.
- initializeZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Bring up connection to zk ensemble and then wait until a master for this cluster and then after
that, wait until cluster 'up' flag has been set.
- INITIALIZING_FLAG - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- initialPath - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- initialReader - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- initialReaderBlockDistribution - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- initialRegionIndexToServerIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- initialSize() - Method in class org.apache.hadoop.hbase.io.asyncfs.SendBufSizePredictor
-
- initialSize - Variable in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- initialState - Variable in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- initiateCompactionStrategy(MemoryCompactionPolicy, Configuration, String) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- initInmemoryFlushSize(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- initInternal(FSDataInputStream, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Use this before submitting a TableMap job.
- initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Use this before submitting a TableMap job.
- initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Use this before submitting a TableMap job.
- initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Use this before submitting a TableMap job.
- initMetaAndIndex(HFile.Reader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
should be called after initTrailerAndContext
- InitMetaProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
This procedure is used to initialize meta table for a new hbase deploy.
- InitMetaProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- initMetrics(ThriftMetrics) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- initMobCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- initMobFileCache() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
Initializes the mob file cache.
- initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from one or more multiple table snapshots, with one or more scans
per snapshot.
- initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from one or more table snapshots, with one or more scans per
snapshot.
- initMultiWriter(AbstractMultiFileWriter, InternalScanner, Compactor.FileDetails, boolean, boolean, Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
-
- initNamedQueueRecorder(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- initOldLog(FileStatus, Path) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
Loads given log file and it's tracker.
- initOldLogs(FileStatus[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- initOutput(FileSystem, Path, boolean, int, short, long, StreamSlowMonitor) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
-
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ClaimReplicationQueueCallable
-
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.RefreshPeerCallable
-
- initParameter(byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.SwitchRpcThrottleRemoteCallable
-
- initQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- initReader() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Initialize the reader used for pread.
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the log reader with a particular stream (may be null).
- initReconfigurable(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- initReplicationQueueStorage(Configuration, ZKWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- initSaslProperties(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Initialize SASL properties for a given RPC protection level.
- initScan() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Check and initialize if application wants to collect scan metrics
- initSize - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
A function to instantiate the metrics source.
- initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
-
This function overrides the initSource in the MetricsBalancer, use
MetricsStochasticBalancerSource instead of the MetricsBalancerSource.
- initSpnego(Configuration, String, String, String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- initState() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- initStreamForCrypto - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- initSyncCache() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTempDir(Configuration) - Method in class org.apache.hadoop.hbase.util.DynamicClassLoader
-
- initThread - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- initTotalCost - Variable in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- initTotalCost - Variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- initTrackerFromOldLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- initTrailerAndContext(ReaderContext, Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- initVisibilityLabelService(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- injectedException - Static variable in class org.apache.hadoop.hbase.security.token.ClientTokenUtil
-
- injectedFailureCount - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Testing
-
- injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Injects the given edge such that it becomes the managed entity.
- injectFault() - Static method in class org.apache.hadoop.hbase.security.token.ClientTokenUtil
-
- injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Inject a nonce generator for testing.
- injectTestFailure(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context, SnapshotProtos.SnapshotFileInfo) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- injectToken(HttpUriRequest, AuthenticatedURL.Token) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Helper method that injects an authentication token to send with the method.
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- inLen - Variable in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- INLINE_BLOCKS_NOT_ALLOWED - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
Error message when trying to use inline block API in single-level mode.
- InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
-
A way to write "inline" blocks into an
HFile
.
- inlineBlockWriters - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Inline block writers for multi-level block index and compound Blooms.
- InlineChore - Class in org.apache.hadoop.hbase.procedure2
-
Inline Chores (executors internal chores).
- InlineChore() - Constructor for class org.apache.hadoop.hbase.procedure2.InlineChore
-
- inMemory - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- inMemory - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether blocks should be flagged as in-memory when being cached
- INMEMORY_COMPACTION_POOL_FOR_TEST - Static variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- inMemoryCompaction() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- inMemoryCompactionInProgress - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- InMemoryCompactionRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactingMemStore.InMemoryCompactionRunnable
-
- inmemoryFlushSize - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- inMemoryPoolSize - Variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- InMemoryProcedureIterator - Class in org.apache.hadoop.hbase.procedure2.store
-
A procedure iterator which holds all the procedure protos in memory.
- InMemoryProcedureIterator(List<ProtoAndProcedure>) - Constructor for class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- inMemstore - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
If false, means this is a meta edit written by the hbase system itself.
- innerBuild() - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- innerBuild() - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCellBuilder
-
- innerBuild() - Method in class org.apache.hadoop.hbase.KeyValueBuilder
-
- inProgressTasks - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- input - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- INPUT_FILES_SEPARATOR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- inputArchive - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- inputCharacterQueue - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- inputColumns - Variable in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- inputFs - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- InputModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the input mode.
- InputModeScreenPresenter(InputModeScreenView, String, List<String>, Function<String, ScreenView>) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- inputModeScreenPresenter - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
-
- inputModeScreenView - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- InputModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The input mode in the top screen.
- InputModeScreenView(Screen, Terminal, int, String, List<String>, Function<String, ScreenView>) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
-
- inputQueue - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.WriterThread
-
- inputRoot - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- inputRoot - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- InputSplit(TableDescriptor, HRegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- inputStream - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- inputStream - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureUtil.CompatStateSerializer
-
- inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- InputStreamBlockDistribution - Class in org.apache.hadoop.hbase.regionserver
-
Computes the HDFSBlockDistribution for a file based on the underlying located blocks for an
HdfsDataInputStream reading that file.
- InputStreamBlockDistribution(FSDataInputStream, StoreFileInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
This should only be called for the first FSDataInputStream of a StoreFile, in
HStoreFile.open()
.
- inputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- inputString - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- InputUser(String, String[]) - Constructor for class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- inQuarantineMode - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- insert(Procedure<?>, Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- insert(Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- insert(Procedure<?>, Procedure<?>[]) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
When a procedure is submitted to the executor insert(proc, null) will be called.
- insert(Procedure<?>[]) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Serialize a set of new procedures.
- insert(Procedure<?>, Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- insert(Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- insert(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- insert(long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- insert(long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- insert(BitSetNode, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- insert(Procedure<?>, Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- insert(Procedure<?>[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- insert(int, CopyOnWriteArrayMap.COWEntry<K, V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- insert(Object) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace
-
- insert(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Insert a node into the tree.
- insert(TNode, Object, AvlUtil.AvlKeyComparator<TNode>, AvlUtil.AvlInsertOrReplace<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Insert a node into the tree.
- insert(long) - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Add a new value from the stream.
- insertBatch() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Merges items from buffer into the samples array in one pass.
- insertDataValue(long) - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Inserts given data value to array of data values to be considered for statistics calculation n
- insertFileIntoStripe(ArrayList<HStoreFile>, HStoreFile) - Static method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Inserts a file in the correct place (by seqnum) in a stripe copy.
- insertIfPartial(ProcedureStoreTracker, ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- insertIntoNSTable(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
Insert the row into ns table
- insertIntoNSTable(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
Insert/update the row into namespace table
- insertIntoNSTable(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- insertNewFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- insertNewFiles(Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds new files, either for from MemStore flush or bulk insert, into the structure.
- insertNewFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- insertOrUpdate(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- insertRegionFilesIntoStoreTracker(List<Path>, MasterProcedureEnv, HRegionFileSystem) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should act with the assumption that the barrier condition has
been satisfied.
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
do a flush snapshot of every region on this rs from the target table.
- INST - Static variable in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- install(Configuration, FileSystem, Stoppable, Thread) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Install a shutdown hook that calls stop on the passed Stoppable and then thread joins against
the passed threadToJoin
.
- installed - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- instance - Static variable in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- instance - Static variable in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- instance - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- instance - Static variable in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
-
- instance - Static variable in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
- instance - Static variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- instance - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.CompactionChecker
-
- instance - Static variable in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- instance() - Static method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.JaxbJsonProviderHolder
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- instance - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.PureJavaComparer
-
Deprecated.
- INSTANCE - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- INSTANCE - Static variable in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.PureJavaConverter
-
- instance - Static variable in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
-
- instance - Variable in class org.apache.hadoop.hbase.zookeeper.InstancePending.InstanceHolder
-
- instanceHolder - Variable in class org.apache.hadoop.hbase.zookeeper.InstancePending
-
Piggybacking on pendingLatch
.
- InstanceHolder(T) - Constructor for class org.apache.hadoop.hbase.zookeeper.InstancePending.InstanceHolder
-
- instanceOfCanUnbuffer - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- InstancePending<T> - Class in org.apache.hadoop.hbase.zookeeper
-
Placeholder of an instance which will be accessed by other threads but is not yet created.
- InstancePending() - Constructor for class org.apache.hadoop.hbase.zookeeper.InstancePending
-
- InstancePending.InstanceHolder<T> - Class in org.apache.hadoop.hbase.zookeeper
-
- instances - Variable in enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration, RetryingCallerInterceptor, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
- instantiate(String, Constructor<T>, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- instantiateBucket(BucketAllocator.Bucket) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- instantiated - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- instantiateException(Class<? extends IOException>) - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Create a
Filter
to apply to all incoming keys (
KeyValues
) to
optionally not include in the job output
- instantiateHStore(ColumnFamilyDescriptor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateRegionScanner(Scan, List<KeyValueScanner>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateSelector(Configuration, Collection<SaslClientAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Instantiates the ProviderSelector implementation from the provided configuration.
- instantiateWithCustomCtor(String, Class<?>[], Object[]) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- inStates(TableState.State) - Method in class org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- inStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
-
Check that table in given states
- instrument() - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- inSync - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- int0(int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- int1(int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- int2(int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- int3(int) - Static method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for an Integer
- integrity - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
-
- Integrity(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- IntegrityFixSuggester(HbckTableInfo, HbckErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.HbckTableInfo.IntegrityFixSuggester
-
- intercept(RetryingCallerInterceptorContext) - Method in class org.apache.hadoop.hbase.client.NoOpRetryableCallerInterceptor
-
- intercept(FastFailInterceptorContext) - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- intercept(RetryingCallerInterceptorContext) - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- intercept(RetryingCallerInterceptorContext) - Method in class org.apache.hadoop.hbase.client.RetryingCallerInterceptor
-
Call this function alongside the actual call done on the callable.
- interceptor - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- interceptor - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- interceptor - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- intermediateIndexHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- intermediateIndexMissCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- INTERN_POOL - Static variable in class org.apache.hadoop.hbase.ServerName
-
Intern ServerNames.
- INTERNAL_UTILS_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.logging.Log4jUtils
-
- internalAdd(MutableSegment, Cell, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- internalAdd(Cell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- internalAdd(Cell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- internalBalancer - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- internalDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- internalDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- internalDeleteSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- internalFlush() - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- internalFlushcache(MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flushing all stores.
- internalFlushcache(Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flushing given stores.
- internalFlushcache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the memstore.
- internalFlushCacheAndCommit(WAL, MonitoredTask, HRegion.PrepareFlushResult, Collection<HStore>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalGetTopBlockLocation(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
Returns an ordered list of hosts that are hosting the blocks for this region.
- InternalLog4jUtils - Class in org.apache.hadoop.hbase.logging
-
The actual class for operating on log4j2.
- InternalLog4jUtils() - Constructor for class org.apache.hadoop.hbase.logging.InternalLog4jUtils
-
- internalName - Variable in enum org.apache.hadoop.hbase.http.ProfileServlet.Event
-
- internalPool - Variable in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
-
- internalPrepareFlushCache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalPreRead(ObserverContext<RegionCoprocessorEnvironment>, Query, AccessController.OpType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- internalQueueIncrement(byte[], byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- internalQueueTincrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- internalRead(ReadableByteChannel, long, ByteBuff.ChannelReader) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- internalRestoreSnapshot(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- internalRestoreSnapshotAsync(String, TableName, boolean, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Execute Restore/Clone snapshot and wait for the server to complete (blocking).
- InternalScan - Class in org.apache.hadoop.hbase.regionserver
-
Special scanner, currently used for increment operations to allow additional server-side
arguments for Scan operations.
- InternalScan(Get) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
-
- InternalScan(Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
-
- InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
-
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[]
instead of RowResults.
- internalTransfer(long, ByteBuff, BiConsumer<ByteBuffer, ByteBuff>) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transferring all remaining bytes from b to the buffers array starting at offset, or
transferring bytes from the buffers array at offset to b until b is filled.
- internEncodedRegionName(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Drop this instance's region name byte array and instead hold a reference to the provided region
name.
- internify(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- Interns - Class in org.apache.hadoop.hbase.metrics
-
Helpers to create interned metrics info
- Interns() - Constructor for class org.apache.hadoop.hbase.metrics.Interns
-
- internTableName(TableName) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Drop this instance's tablename byte array and instead hold a reference to the provided
tablename.
- interrupt() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Handles InterruptedExceptions in client calls.
- interruptedExceptionNoThrow(InterruptedException, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Log the InterruptedException and interrupt current thread
- interruptIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Only interrupt once it's done with a run through the work loop.
- interruptIfNecessary() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Only interrupt once it's done with a run through the work loop.
- interruptOldWALsCleaner() - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- interruptOrAbortWhenFail(ReplicationSourceManager.ReplicationQueueOperation) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Refresh replication source will terminate the old source first, then the source thread will be
interrupted.
- interruptRegionOperations() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- interval - Variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- INTERVAL_PATTERN - Static variable in class org.apache.hadoop.hbase.util.PrettyPrinter
-
- INTERVAL_REGEX - Static variable in class org.apache.hadoop.hbase.util.PrettyPrinter
-
- intervalTime - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Check how many bytes is required to store value.
- intToByte(int) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote invalid hash type.
- INVALID_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- INVALID_KEY_IN_MAP - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Normally invalid key is null, but in the map null is the result for "no key"; so use the
following constant value in these maps instead.
- INVALID_REGION_NAME_FORMAT_MESSAGE - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- invalidACLFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- invalidate() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- invalidate() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
-
Thrown if a request is table schema modification is requested but made for an invalid family
name.
- InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
default constructor
- InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor
- InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor taking another exception.
- InvalidHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
Thrown when an invalid HFile format is detected
- InvalidHFileException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
constructor
- InvalidHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
Constructor
- InvalidLabelException - Exception in org.apache.hadoop.hbase.security.visibility
-
- InvalidLabelException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
-
- InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate an invalid RowFilter.
- InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- InvalidWALDataException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
-
Deprecated.
- InvalidWALDataException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
-
Deprecated.
- invert(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Copy a given matrix into a new matrix, transforming each row index and each column index
according to the inverse of the randomization scheme that was created at construction time.
- invertIndices(int[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Given an array where each element indices[i]
represents the randomized column index
corresponding to randomized row index i
, create a new array with the corresponding
inverted indices.
- inViolation - Variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- invocations - Variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor.PassthroughInvocationHandler
-
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
-
- invokeCallBack(byte[], byte[], CResult) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- invokeMethod(Object, String, Object...) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
Get and invoke the target method from the given object with given parameters
- invokeSetStoragePolicy(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- inWalReplay - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- IO_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- IO_STOREFILE_BLOOM_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Target Bloom block size.
- IO_STOREFILE_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Bloom filters
- IO_STOREFILE_BLOOM_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Specifies the target error rate to use when selecting the number of keys per Bloom filter.
- IO_STOREFILE_BLOOM_MAX_FOLD - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Maximum folding factor allowed.
- IO_STOREFILE_BLOOM_MAX_KEYS - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
For default (single-block) Bloom filters this specifies the maximum number of keys.
- IO_STOREFILE_DELETEFAMILY_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Delete Family Bloom filters
- ioe - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- ioEngine - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- IOEngine - Interface in org.apache.hadoop.hbase.io.hfile.bucket
-
A class implementing IOEngine interface supports data services for
BucketCache
.
- ioErrorStartTime - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- ioErrorsTolerationDuration - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Duration of IO errors tolerated before we disable cache, 1 min as default
- IOErrorWithCause(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
-
- ioHit(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- ioHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- ioHitTime - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- ioOptimizedMode - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- IPC_SERVER_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
- IPC_SERVER_PRIORITY_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
- IPC_SERVER_REPLICATION_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
- IpcClientSpanBuilder - Class in org.apache.hadoop.hbase.client.trace
-
Construct Span
instances originating from the client side of an IPC.
- IpcClientSpanBuilder() - Constructor for class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
- IpcServerSpanBuilder - Class in org.apache.hadoop.hbase.server.trace
-
Construct Span
instances originating from the server side of an IPC.
- IpcServerSpanBuilder(RpcCall) - Constructor for class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
-
- IPCUtil - Class in org.apache.hadoop.hbase.ipc
-
Utility to help ipc'ing.
- IPCUtil() - Constructor for class org.apache.hadoop.hbase.ipc.IPCUtil
-
- is - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- is32BitJVM() - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Determines if we are running in a 32-bit JVM.
- IS_ACTIVE_MASTER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- IS_ACTIVE_MASTER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- IS_META - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute which denotes if it is a catalog
table, either hbase:meta
.
- IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- IS_META - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- IS_META_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- IS_MOB - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IS_MOB - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- IS_MOB_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- IS_MOB_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- IS_ROOT - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- isa - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher.ClusterMetricsEncoder
-
- isa - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- isAarch64() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the arch is aarch64;
- isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
-
Check if the server or client was aborted.
- isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isAborted() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.WarnOnlyAbortable
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- isAborted() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isAborted() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- isAbortInProgress - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.AbortProcedureFuture
-
- isAbortNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier abort znode path
- isAbortPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier abort znode path
- isAboveHighWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Return the FlushType if global memory usage is above the high watermark
- isAboveHighWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Return the FlushType if we are above the memstore high water mark
- isAboveLowWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Return the FlushType if we're above the low watermark
- isAboveLowWaterMark() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Return the FlushType if we're above the low watermark
- isAcceptableAddress(InetAddress) - Method in interface org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition
-
Condition on which to accept inet address
- isAccessControllerRunning(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- isAclRegion(Region) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Returns true
if the given region is part of the _acl_
metadata table.
- isAclSyncToHdfsEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- isAclSyncToHdfsEnabled(TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- isAclTable(TableDescriptor) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Returns true
if the given table is _acl_
metadata table.
- isAcquiredNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this the exact procedure barrier acquired znode
- isAcquiredPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier acquired znode path
- isActionComplete(int, Row) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Checks if the action is complete; used on error to prevent needless retries.
- isActive() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- isActive() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- isActive() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
Tell the idle connection sweeper whether we could be swept.
- isActive() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is currently the active master or not.
- isActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns true if master is the active one
- isActiveStorefile(FileStatus, HStore) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- isAdjacent(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if region is adjacent, either just before or just after this one.
- isAfterSplit - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isAfterSplit() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Test for the availability of the web server
- isAlive() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- isAllFamilies(Collection<HStore>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns True if passed Set is all families in the region.
- isAllFiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns true
if major compaction or all files are compacted
- isAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isAllModified() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Returns true, if all the procedures has been modified.
- isAllModified() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- isAllowed() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- isAllowedDelegationTokenOp(UserGroupInformation) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- isAllTime(long, long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
-
- isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if it is for all time
- isAlt(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- isAlt() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- isAlwaysCopyFiles() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- isAlwaysFramed - Variable in enum org.apache.hadoop.hbase.thrift.ImplType
-
- isAlwaysFramed() - Method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- isAmd64() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the arch is amd64;
- isAnyRPCcancelled() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- isAnyRPCcancelled() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- isArchiveDataDir(Path) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isArchivedFileStillReferenced(Path, Map<Path, Integer>) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Check if for a give file in archive, if there are other snapshots/tables still reference it.
- isArchivedLogFile(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- isArchiveNamespaceDir(Path) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isArchiveTableDir(Path) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isArchivingEnabled(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
-
Check to see if the table is currently marked for archiving
- isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.ReversedRowRange
-
- isAscendingOrder() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isAtomic() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- isAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Return true if authorization is supported and enabled
- isAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- isAuthRenewalChoreEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Returns true if the chore to automatically renew Kerberos tickets (from keytabs) should be
started.
- isAutoAdjust() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- isAvailable() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- isAvailable() - Method in class org.apache.hadoop.hbase.master.procedure.TableQueue
-
- isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isAvailable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is available (not closed and not closing)
- isBackReferencesDir(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Checks if the specified directory path is a back reference links folder.
- isBadJvmVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
-
Return true if the current JVM version is known to be unstable with HBase.
- isBalancerDecisionRecording - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- isBalancerDecisionRecording - Variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the balancer.
- isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the balancer.
- isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isBalancerEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Return true if the balance switch is on, false otherwise
- isBalancerRan() - Method in class org.apache.hadoop.hbase.client.BalanceResponse
-
Returns true if the balancer ran, otherwise false.
- isBalancerRejectionRecording - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- isBalancerRejectionRecording - Variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- isBaseZnodeAclSetup(List<ACL>) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Checks whether the ACLs returned from the base znode (/hbase) is set for secure setup.
- isBatchStarted() - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- isBetterSelection(List<HStoreFile>, long, List<HStoreFile>, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
- isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- isBlink() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobCopy encoding, false otherwise.
- isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobVar encoding, false otherwise.
- isBlockCacheEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns True if hfile DATA type blocks should be cached (You cannot disable caching of INDEX
and BLOOM type blocks).
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isBloom() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block category is bloom filter
- isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- isBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- isBoolean(String) - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- isBootstrapNamespace() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- isBroken() - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
Whether the stream is broken.
- isBroken() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- isBroken() - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- isBrowser(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
This method interrogates the User-Agent String and returns whether it refers to a browser.
- isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- isBulkLoadResult() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- isBulkLoadResult() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Check if this storefile was created by bulk load.
- isBypass() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.NoopQuotaLimiter
-
- isBypass() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Returns true if the limiter is a noop
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Returns true if there is no quota information associated to this object
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Returns true if there is no quota information associated to this object
- isBypassable() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- isByTable - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- isByteBufferReadable(FSDataInputStream) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
- isCacheBloomsOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache bloomfilter blocks on write
- isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isCacheDataOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache data blocks on write
- isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isCacheEnabled() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- isCacheEnabled - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- isCacheIndexesOnWrite() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should cache index blocks on write
- isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isCacheMobBlocks(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether the scan contains the information of caching blocks.
- isCanceled() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- isCancelled() - Method in interface org.apache.hadoop.hbase.client.Cancellable
-
- isCancelled() - Method in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- isCancelled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- isCancelled() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- isCancelled() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- isCancelled() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- isCancelled() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isCarryingRegion(ServerName, RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query on the catalog janitor state (Enabled/Disabled?).
- isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query on the catalog janitor state.
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isCatalogTable(TableName) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
- isCellAfterCurrentWriter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- isCellAuthorizationEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Return true if cell authorization is supported and enabled
- isCellAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
-
- isCellAuthorizationSupported(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- isCellBlock() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- isCellTTLExpired(Cell, long, long) - Static method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
nn * @return true if the cell is expired
- isCellVisibilityEnabled(Connection) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Return true if cell visibility features are supported and enabled
- isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
-
- isCheckOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only the MemStore should be checked.
- isCheckOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only StoreFiles should be checked.
- isChoreScheduled(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the chore is scheduled with the implementer of this interface
- isChunkInPool(int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- isClassExempt(String, String[]) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Determines whether the given class should be exempt from being loaded by this ClassLoader.
- isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query on the cleaner chore state (Enabled/Disabled?).
- isCleanerChoreEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the cleaner chore.
- isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isCleanerChoreEnabled(RpcController, MasterProtos.IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isCleanerChoreEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isClientCellBlockSupport(RpcCallContext) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- isClientCellBlockSupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
If the client connected and specified a codec to use, then we will use this codec making
cellblocks to return.
- isClientCellBlockSupported() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns whether the path is supposed to be readable by the client and DOES NOT contain
sensitive information (world readable).
- isClientRunning(DFSClient) - Method in interface org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.DFSClientAdaptor
-
- isClientScannerAsyncPrefetch() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- isClosed() - Method in interface org.apache.hadoop.hbase.client.AsyncConnection
-
Returns whether the connection is closed or not.
- isClosed() - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns whether the connection is closed or not.
- isClosed() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- isClosed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is closed
- isClosed() - Method in class org.apache.hadoop.hbase.SharedConnection
-
- isClosed - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isClosed() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isClosedOrAbnormallyClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isCloseRegion() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
-
- isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosing() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns True if closing process has started
- isClosingOrClosedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClusterIdSet - Variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- isClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Return whether the cluster is running.
- isClusterRunning() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- isClusterShutdown() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isClusterUp() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns True if cluster is up; false if cluster is not up (we are shutting down).
- isClusterUp() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns True if the cluster is up.
- isClusterUp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns True if cluster is up; false if cluster is not up (we are shutting down).
- isClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Checks if cluster is up.
- isCocked() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Returns True is this is a 'cocked', fresh instance, and not one that has already fired.
- isCodelQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- isCollectionEqual(Collection<String>, Collection<String>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- isColumnQualifierChanged(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- isColumnSorted() - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
-
- isCombinedBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- isCompact - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isCompact() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isCompacted() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- isCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- isCompactedFile(FileStatus, HStore) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- isCompacting() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- isCompacting(MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- isCompaction - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- isCompaction() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- isCompaction(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
Whether we are creating a new file in a compaction
- isCompactionEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCompactionEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Check if the compaction enable flag of the table is true.
- isCompactionMarker(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Returns true if the given cell is a serialized WALProtos.CompactionDescriptor
- isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns True if the flush requested a compaction, else false
- isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
- isCompactionResultFile(FileStatus, HStore) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- isCompactionsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- isComplete() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- isComplete() - Method in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- isComplete() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- isComplete() - Method in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- isCompleted(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- isCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Check if the entire procedure has globally completed, or has been aborted.
- isCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
-
- isCompletelyFree() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isCompletelyMigrateSFT(int) - Method in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- isCompressedOrEncrypted() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Returns true when on-disk blocks are compressed, and/or encrypted; false otherwise.
- isCompressTags() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns Whether KV tags should be compressed along with DataBlockEncoding.
- isCompressTags() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isCompressTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isConnected() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- isConnected() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- isConnectionException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
Check if the exception is something that indicates that we cannot contact/communicate with the
server.
- isConnectionOpen() - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- isConnectionOpen() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- isConnectionOpen() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Check if given encoder has this id.
- isCorrupt() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.SplitWALResult
-
- isCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
Returns true if the file is corrupted
- isCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- isCreateRootDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- isCreateTable() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- isCreateWALDir() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
- isCtrl(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- isCtrl() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- isCurrentKeyRolled() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- isCursor() - Method in class org.apache.hadoop.hbase.client.Result
-
Return true if this Result is a cursor to tell users where the server has scanned.
- isData() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block type is encoded or unencoded data block
- isDataChunk() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- isDataFileSystemOk() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns true
when the data file system is available, false
otherwise.
- isDateTieredStoragePolicyEnable() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
Deprecated.
- isDead() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskAndWeakRefPair
-
- isDeadlineQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener
-
Check if we know if a server is dead.
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isDecodeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- isDefaultMetaRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns true if this replicaId corresponds to default replica for the region
- isDefaultReplica(RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns true if this region is a default replica for the region
- isDegenerate() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if RegionInfo is degenerate...
- isDelay() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
Returns True if the entry is a delay flush task
- isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDeleteColumnFamily(TableDescriptor, TableDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Find out whether all column families in unmodifiedTableDescriptor also exists in the
modifiedTableDescriptor.
- isDeleteColumnOrFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumnOrFamily(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Returns True if this cell is a delete family or column type.
- isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDeleted() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer.ZKData
-
- isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- isDeleted(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Check if the specified cell buffer has been deleted by a previously seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
This method is not idempotent, we will save some info to judge VERSION_MASKED.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
Check if the specified Cell buffer has been deleted by a previously seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker
-
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns true if Delete Family Bloom filters are enabled in the given configuration
- isDeleteFamilyVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteFamilyVersion(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDeleteType(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteType(Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- isDictionary(byte[]) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- isDirectBufferPooled() - Method in class org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
-
- isDirectory(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
- isDisabled() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is disabled.
- isDisabled() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
- isDisabledOrDisabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
- isDisableSpaceViolationPolicy(SpaceViolationPolicy, SpaceViolationPolicy) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- isDisabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
Returns True if table is disabling.
- isDisplayByDefault() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldInfo
-
- isDistributed() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.DumpOptions
-
- isDistributedFileSystem(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns True is fs
is instance of DistributedFileSystem n
- isDone() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- isDone() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- isDone() - Method in class org.apache.hadoop.hbase.ipc.Call
-
- isDone() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- isDone() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- isDone() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Give the tracker a chance to declare it's done based on only the timestamp to allow an early
out.
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- isDone() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isDone() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns True if origin exception was a do not retry type.
- isDryRun() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Returns true if the balancer should run in dry run mode, otherwise false.
- isEmpty() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.ListRowAccess
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying Cell [] is empty or not
- isEmpty() - Method in interface org.apache.hadoop.hbase.client.RowAccess
-
Returns true if there are no elements.
- isEmpty() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- isEmpty() - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Returns true if the block index is empty.
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- isEmpty() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isEmpty() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
Returns True if an 'empty' lastReport -- no problems found.
- isEmpty() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Returns true, if there are no active procedures in this BitSetNode, else false.
- isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Returns true, if no procedure is active, else false.
- isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- isEmpty(String) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- isEmpty() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns if the store is empty.
- isEmpty() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- isEmpty() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns whether there are non-null elements in the list
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Returns whether the segment has any cells
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Returns true if there are no current delete, false otherwise
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Returns whether the segment has any cells
- isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Returns true if no locations have been added, false otherwise
- isEmpty() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- isEmpty() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Returns true when range
is of zero length, false otherwise.
- isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Returns true when this range is of zero length, false otherwise.
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedList
-
- isEmpty() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- isEmptyArchiveDirDeletable(Path) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isEmptyDirDeletable(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Check if a empty directory with no subdirs or subfiles can be deleted
- isEmptyDirDeletable(Path) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Check if a empty directory with no subdirs or subfiles can be deleted
- isEmptyDirDeletable(Path) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isEmptyRegionServerPresent() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- isEmptyStartRow(byte[]) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- isEmptyStopRow(byte[]) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- isEmptyStoreFile(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
-
The FIFOCompactionPolicy only choose the TTL expired store files as the compaction candidates.
- isEnable() - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- isEnabled() - Method in class org.apache.hadoop.hbase.client.TableState
-
- isEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
True if we should derive StoreFile HDFSBlockDistribution from the underlying input stream
- isEnabled(Configuration) - Static method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- isEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
If throttling is enabled
- isEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- isEnabledOrEnabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
- isEnabling() - Method in class org.apache.hadoop.hbase.client.TableState
-
- isEncodedRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Figure if the passed bytes represent an encoded region name or not.
- isEncodedRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Returns true when src
appears to be positioned an encoded value, false otherwise.
- isEncryptionEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Returns true if the column family encryption feature is enabled globally.
- isEndOfFile() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- isEndOfLabel(byte) - Static method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- isEndOfLine() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- isEnteringRun() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.EvictionThread
-
Used for the test.
- isEnteringRun() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
Used for the test.
- isEofState() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- isEqual(RegionLocations, RegionLocations) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isError - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- isEvictBlocksOnClose() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should evict cached blocks from the blockcache on close
- isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isEvictionInProgress() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- isEvictionInProgress() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- isExceedSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
Returns true if region size exceed the sizeToCheck
- isExceedThrottleQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isExceedThrottleQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- isExceedThrottleQuotaEnabled(Connection) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- isExceedThrottleQuotaRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isExclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
Returns true if the current range's key is exclusive
- isExclusive() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Only one instance of hbck can modify HBase at a time.
- isExecutorServiceRunning(String) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- isExistingSource() - Method in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
Returns whether or not this MetricRegistry is for an existing BaseSource
- isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Calls fs.exists().
- isExpired(long, long, long) - Method in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- isExpired(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- isExpired(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- isExpired(long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- isFailed() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns true if the procedure has failed.
- isFailed() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFailedServer(Address) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
-
Check if the server should be considered as bad.
- isFallbackEnabled() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- isFamilyDir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default, we require all scan's column families to be present.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
The only CF this filter needs is given column family.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- isFatalConnectionException(RPCProtos.ExceptionResponse) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
Returns True if the exception is a fatal connection exception.
- isFavoredNodeApplicable(RegionInfo) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- isFifoQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- isFile() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
Check to see if this is a file or a directory
- isFile() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileablePath
-
- isFile() - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileableStoreFile
-
- isFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
Check if the path is referencing a file.
- isFile(FileSystem, Boolean, Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
-
- isFileClosed(DistributedFileSystem, Method, Path) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
Call HDFS-4525 isFileClosed if it is available.
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
Should the master delete the file or keep it?
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Returns true if this is a file scanner.
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Returns true if this is a file scanner.
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- isFilledUp - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- isFilterDone() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
Returns True if a filter rules the scanner is over, done.
- isFilterDoneInternal() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- isFinished() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Check to see if the snapshot is finished, where finished may be success or failure.
- isFinished() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isFinished(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Return true if the procedure is finished.
- isFinished(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- isFinished() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- isFinished() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- isFinished() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.SplitWALResult
-
- isFirst() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if this is first Region in Table
- isFirst() - Method in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Float32 encoding, false
otherwise.
- isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Float64 encoding, false
otherwise.
- isFixedInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Int16 encoding, false
otherwise.
- isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Int32 encoding, false
otherwise.
- isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Int64 encoding, false
otherwise.
- isFixedInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width Int8 encoding, false
otherwise.
- isFlush - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- isFlushRequested() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- isFlushSize(MemStoreSize) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Returns true if the memstores were flushed, else false
- isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_NO_COMPACTION_NEEDED or
FLUSHED_NO_COMPACTION_NEEDED.
- isForceSync() - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- isFramed - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isFramed() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- isFromPool() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- isFull() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- isFullRegionScan(Scan, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Returns true if general Bloom (Row or RowCol) filters are enabled in the given configuration
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
-
- isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- isGetScan() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isGlobalEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- isGo() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
- isGood(RegionLocations, int) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
- isGreaterThan(long, long, boolean) - Method in class org.apache.hadoop.hbase.RegionLocations
-
- isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Deprecated.
Returns whether or not the given name should be interpreted as a group principal.
- isGuaranteedClientSideOnly() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
Returns true if we know no mutation made it to the server, false otherwise.
- isGZIPOutputStreamFinishBroken() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the finish() method of GZIPOutputStream is broken
- isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Return whether or not Kerberos authentication is configured for Hadoop.
- isHashCached() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- isHBaseClusterRunning() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Return whether the hbase cluster is running.
- isHBaseClusterRunning() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not secure authentication is enabled for HBase.
- isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Returns true if security is enabled, false otherwise
- isHdfs() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.DumpOptions
-
- isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Return true if this is a filesystem whose scheme is 'hdfs'.
- isHdfsAclSet(Table, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- isHdfsAclSet(Table, String, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- isHdfsAclSet(Table, String, TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- isHdfsAclSet(Table, String, String, TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
Check if user global/namespace/table HDFS acls is already set
- isHdfsRegioninfoPresent() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- isHealthCheckerConfigured() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isHealthy() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isHeartbeatMessage() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- isHeartbeatMessage() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
Returns true when the most recent RPC response indicated that the response was a heartbeat
message.
- isHeldByCurrentThread(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Test whether the given id is already locked by the current thread.
- isHelpCommand(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- isHexDigit(char) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- isHFile() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- isHFile() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this is HFile.
- isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isHFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isHFileFormat(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileFormat(FileSystem, FileStatus) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHsync(long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- isHttpEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isHttpsEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isIdle() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- isIgnoreRegionsInTransition() - Method in class org.apache.hadoop.hbase.client.BalanceRequest
-
Returns true if the balancer should execute even if regions are in transition, otherwise false.
- isIncludeRelatedReturnCode(Filter.ReturnCode) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
- isIncludesMvcc() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isIncludesTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isIncreasing(ProcedureProtos.Procedure, ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- isIndex() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns whether this block category is index
- isIndexChunk() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- isInit - Static variable in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
- isInitialChoreComplete() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- isInitialized() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- isInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master has completed with its initialization and is ready.
- isInitialized() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Returns true if master is initialized
- isInitialized() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Checks if namespace auditor is initialized.
- isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- isInitializing() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is in maintenance mode.
- isInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
-
- isInMemory() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns True if we are to favor keeping all values for this column family in the HRegionServer
cache.
- isInMemory() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks in this file should be flagged as in-memory
- isInMemStore() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- isInProcedurePath(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this a procedure related znode path? TODO: this is not strict, can return true if had name
just starts with same prefix but is different zdir.
- isInRecoverMetaState() - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- isInReplay() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- isInReplay() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- isInReplay() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- isInReturnCodes(Filter.ReturnCode, Filter.ReturnCode...) - Static method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isInSafeMode(DistributedFileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Inquire the Active NameNode's safe mode status.
- isInState(RegionState.State...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
Notice that, we will return true if expected
is empty.
- isInState(ServerState...) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- isInStates(TableState.State...) - Method in class org.apache.hadoop.hbase.client.TableState
-
Static version of state checker
- isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Checks the user has privileges to access to instrumentation servlets.
- isInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
Returns true if the throwable comes an interruption, false otherwise.
- isInterrupted - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- isInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- isInvalid(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Checks whether the key is invalid (e.g.
- isInViolation(SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
Checks if the given snapshot
is in violation, allowing the snapshot to be null.
- isInViolation() - Method in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Returns true
if the quota is being violated, false
otherwise.
- isInViolation() - Method in interface org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
-
Returns true
if the quota is being violated, false
otherwise.
- isInViolationAndPolicyDisable(TableName, QuotaObserverChore) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Method to check if a table is in violation and policy set on table is DISABLE.
- isIterationComplete(int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
Returns true if we exhausted searching all row ranges.
- isIterationFinished() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- isJumbo() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
- isKeepAliveMasterConnectedAndRunning(ConnectionImplementation.MasterServiceState) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isLargeEnoughForMerge(SimpleRegionNormalizer.NormalizerConfiguration, SimpleRegionNormalizer.NormalizeContext, RegionInfo) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Return true
when regionInfo
has a size that is sufficient to be considered for
a merge operation, false
otherwise.
- isLargeLog - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- isLargeLog() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- isLast() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if this is last Region in Table
- isLastRangeAndOpening(MetaTableAccessor.ReplicationBarrierResult, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- isLatestCellFromMemstore() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns True if this KeyValue has a LATEST_TIMESTAMP timestamp.
- isLeftJustify() - Method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
- isLegalColumnFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Check if the column family name is legal.
- isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Check passed byte array, "tableName", is legal user-space table name.
- isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Valid namespace characters are alphabetic characters, numbers, and underscores.
- isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Qualifier names can only contain 'word' characters [\p{IsAlphabetic}\p{Digit}]
or
'_', '.' or '-'.
- isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a link
- isLinked(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return true if the node is linked to a list, false otherwise
- isLinux() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is linux.
- isLoadingCfsOnDemandDefault - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
The default setting for whether to enable on-demand CF loading for scan requests to this
region.
- isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- isLocalAddress(InetAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Given an InetAddress, checks to see if the address is a local address, by comparing the address
with all the interfaces on the node.
- isLocked() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- isLocked() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- isLocked() - Method in interface org.apache.hadoop.hbase.procedure2.LockStatus
-
Return whether this lock has already been held,
Notice that, holding the exclusive lock or shared lock are both considered as locked, i.e, this
method usually equals to
hasExclusiveLock() || getSharedLockCount() > 0
.
- isLockedWhenLoading() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isLockReady(Procedure<?>, Queue<T>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- isLoginFromKeytab() - Method in class org.apache.hadoop.hbase.security.User
-
Returns true if user credentials are obtained from keytab.
- isLogLevelChangeAllowed(String, String[]) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- isLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- isLogTraceEnabled - Static variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- isLowReplicationRollEnabled() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- isMajor() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns true
if major compaction
- isMajor - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isMajorCompactionResult() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- isMajorCompactionResult() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this file was made by a major compaction.
- isManaged - Variable in class org.apache.hadoop.hbase.http.HttpServer.ListenerInfo
-
Boolean flag to determine whether the HTTP server should clean up the listener in stop().
- isManagedConnection - Variable in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
Should QutoaRetriever manage the state of the connection, or leave it be.
- isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- isMaster - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
Flag indicating whether we're in charge of rolling/expiring keys
- isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
- isMasterCanHostUserRegions(Configuration) - Static method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
- isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check whether Master is in maintenance mode.
- isMasterInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check whether master is in maintenance mode
- isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isMasterInMaintenanceMode(RpcController, MasterProtos.IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- isMasterRunning(MasterProtos.MasterService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceStubMaker
-
- isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isMasterRunning(MasterServices) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- isMasterSwitchEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- isMatchingRegionLocation(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure
-
The RegionStateNode will not have a location if a confirm of an OPEN fails.
- isMatchingRegionLocation(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Moved out here so can be overridden by the HBCK fix-up SCP to be less strict about what it will
tolerate as a 'match'.
- isMatchingTail(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare path component of the Path URI; e.g.
- isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare path component of the Path URI; e.g.
- isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare path component of the Path URI; e.g.
- isMax(byte) - Method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Return true when val
is the maximum value
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns if max column range is inclusive.
- isMaximumWait(long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
n * @return True if we have been delayed > maximumWait
milliseconds.
- isMD5Hash(String) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- isMemberNode(String, String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- isMemStoreFlushingInMemory() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- isMergeable(MasterProcedureEnv, RegionState) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isMergeable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is mergeable
- isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMerged - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- isMerged() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the merge switch.
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Merge switch.
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isMergeEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the merge enable flag of the table is true.
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the region merge enable flag of the table is true.
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Check if the region merge enable flag of the table is true.
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- isMergeEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isMergeQualifierPrefix(Cell) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns True if the column in cell
matches the regex 'info:merge.*'.
- isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOrOfflineOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNewOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMeta(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- isMeta() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- isMetaAssigned() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Notice that, this only means the meta region is available on a RS, but the AM may still be
loading the region states from meta, so usually you need to check
AssignmentManager.isMetaLoaded()
first
before checking this method, unless you can make sure that your piece of code can only be
executed after AM builds the region states.
- isMetaBlock(BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Check if block type is meta or index block
- isMetaClearingException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- isMetaEdit() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- isMetaEditFamily(byte[]) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
- isMetaEditFamily(Cell) - Static method in class org.apache.hadoop.hbase.wal.WALEdit
-
Replaying WALs can read Cell-at-a-time so need this method in those cases.
- isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- isMetaFile(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- isMetaLoaded() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Return whether AM finishes the meta loading, i.e, the region states rebuilding.
- isMetaLoaded(AssignmentManager) - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- isMetaProcedure(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- isMetaRegion(byte[]) - Static method in class org.apache.hadoop.hbase.client.MasterCallable
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns true if this region is a meta region
- isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns true if this region is a meta region.
- isMetaRegion() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaRegion() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if this region is a meta region
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Checks if this table is hbase:meta
region.
- isMetaRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isMetaRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isMetaRegionInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isMetaRegionReplicaReplicationEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if hbase:meta Region Read Replica is enabled.
- isMetaTable() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Checks if the table is a hbase:meta
table
- isMetaTable() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Checks if the table is a hbase:meta
table
- isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if this region is from hbase:meta
- isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Checks if the table is a hbase:meta
table
- isMetaTableName(TableName) - Static method in class org.apache.hadoop.hbase.TableName
-
Returns True if tn
is the hbase:meta table name.
- isMetaTableOp(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- isMetaZNodePath(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns True is the fully qualified path is for meta location
- isMetaZNodePrefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
Returns True if meta znode.
- isMigration(Class<?>) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Returns if min column range is inclusive.
- isMissing(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Returns true if the argument is non-null and not whitespace
- isMissing() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
Returns true if the file is missing
- isMobEnabled() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Gets whether the mob is enabled for the family.
- isMobEnabled() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isMobEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isMobFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Checks if the file is a MOB file
- isMobFileExpired(ColumnFamilyDescriptor, long, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Checks if the mob file is expired.
- isMobReferenceCell(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Whether the current cell is a mob reference cell.
- isMobRefFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Checks if the file is a MOB reference file, created by snapshot
- isMobRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets whether the current RegionInfo is a mob one.
- isMobRegionName(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Gets whether the current region name follows the pattern of a mob region name.
- isModified(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- isModified(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- isNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- isNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isNamespacesAndTableCFsEqual(ReplicationPeerConfig, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- isNamespacesEqual(Set<String>, Set<String>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isNeedCursorResult() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isNeeded() - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- isNeeded() - Method in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- isNeeded() - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- isNeedProcessConnectionHeader() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- isNegotiatedQopPrivacy() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- isNewKey(Cell) - Method in class org.apache.hadoop.hbase.util.BloomContext
-
Returns true if the cell is a new key as per the bloom type
- isNewKey(Cell) - Method in class org.apache.hadoop.hbase.util.RowBloomContext
-
- isNewKey(Cell) - Method in class org.apache.hadoop.hbase.util.RowColBloomContext
-
- isNewRowOrType(Cell, Cell) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
nn * @return True if we have crossed over onto a new row or type
- isNewVersionBehavior() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
By default, HBase only consider timestamp in versions.
- isNewVersionBehavior() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- isNext(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if region is next, adjacent but 'after' this one.
- isNextBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- isNextFinished() - Method in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- isNextFinished() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
-
- isNonDaemonThreadRunning() - Static method in class org.apache.hadoop.hbase.util.Threads
-
Checks whether any non-daemon thread is running.
- isNoReadahead() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isNormalizationEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if normalization enable flag of the table is true.
- isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if normalization enable flag of the table is true.
- isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Check if normalization enable flag of the table is true.
- isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the region normalizer.
- isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the region normalizer
- isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
Return true
if region normalizer is on, false
otherwise
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
-
Return true if region normalizer is on, false otherwise
- isNoSuchColumnFamilyException(Throwable) - Static method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isNot(String) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- isNotFamilyOrQualifierPermission(TablePermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Returns true if the filter is empty
- isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
is null, false otherwise.
- isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance supports encoding null values.
- isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric encoding, false otherwise.
- isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric encoding and is
Infinite
, false otherwise.
- isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric encoding and is
NaN
, false otherwise.
- isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric encoding and is 0
,
false otherwise.
- isOffheap() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- isOffHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- isOffheap() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- isOffheapMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- isOffline() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- isOffline() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if this region is offline.
- isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOffPeak() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Returns true
if compaction is Off-peak
- isOffPeak - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
Returns whether targetHour
is off-peak hour
- isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
Returns whether it is off-peak hour
- isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours.OffPeakHoursImpl
-
- isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours.OffPeakHoursImpl
-
- ISOLATION_LEVEL - Static variable in class org.apache.hadoop.hbase.client.Query
-
- IsolationLevel - Enum in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- IsolationLevel() - Constructor for enum org.apache.hadoop.hbase.client.IsolationLevel
-
- isOldEnough(FileStatus) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- isOldEnoughForMerge(SimpleRegionNormalizer.NormalizerConfiguration, SimpleRegionNormalizer.NormalizeContext, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Return true
when regionInfo
has a creation date that is old enough to be
considered for a merge operation, false
otherwise.
- isOldMobFileName(String) - Static method in class org.apache.hadoop.hbase.mob.MobFileName
-
- isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- isOnHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- isOnline() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is started This method is used for testing.
- isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Report the status of the server.
- isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- isOnline() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Whether the manager is able to fully return group metadata
- isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupStartupWorker
-
- isOnlineLogProviderEnabled - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isOnlineLogProviderEnabled - Variable in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpen(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Checks whether the key indicates an open interval boundary (i.e.
- isOpen(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpeningOrFailedOpenOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpeningOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOperationPending(int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- isOperationRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isOperationRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active RPC call to a
database command.
- isOptionsSupported(String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance writes encoded byte[]
's which preserve the natural sort
order of the unencoded value.
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- isOutstandingSyncs() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
Returns True if outstanding sync futures still
- isOutstandingSyncsFromRunners() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- isOverlap(RegionInfo) - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if an overlap in region range.
- isOverlap(RegionInfo, Pair<RegionInfo, RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- isOverloaded - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isParallelSeekEnabled() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- isParentFinished(byte[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- isPartial() - Method in class org.apache.hadoop.hbase.client.Result
-
- isPartial() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
check whether the peer is enabled or not
- isPeerEnabled() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns peer enabled or not
- isPeerEnabled() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Test whether the peer is enabled.
- isPeerEnabled(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Test whether a replication peer is enabled.
- isPeerEnabled(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- isPeerProcedure(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- isPeerQuorumAddress(String) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- isPending(AsyncNonMetaRegionLocator.LocateRequest) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- isPeriodic() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Memory IO engine is always unable to support persistent storage for the cache n
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
File IO engine is always able to support persistent storage for the cache n
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
File IO engine is always able to support persistent storage for the cache n
- isPersistent() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Returns true if persistent storage is supported for the cache when shutdown
- isPluggableQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- isPluggableQueueWithFastPath(String, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- isPreadAllBytes - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- isPreadAllBytes() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- isPrefetchBlocksOnOpen() - Method in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
Returns true if we should prefetch blocks into the blockcache on open
- isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- isPreprocessedMask(byte[]) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- isPrimary() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- isPrimaryReplica - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- isPrimaryReplicaBlock - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- isPrimaryReplicaReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- isPrimaryReplicaStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- isPrintableChar(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified procedure is done.
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Check if the procedure is finished successfully
- isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the specified procedure.
- isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check the current state of the specified procedure.
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isProcedureOwner(long, User) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Check if the user is this procedure's owner
- isProcessed() - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- isPut(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns True if this cell is a Put.
- isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- isQuotaEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Returns true if the support for quota is enabled
- isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- isQuotaInitialized() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns a boolean indicating whether the quote was escaped or not
- isRangeFinished(long, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- isRaw() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns True if this Scan is in "raw" mode.
- isRawMobScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether it's a raw scan.
- isReachedNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this the exact procedure barrier reached znode
- isReachedPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier reached znode path
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- isReadEmptyValueOnMobCellMiss(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether return null value when the mob file is missing or corrupt.
- isReaderRunning - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- isReaderRunning() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
Returns whether the reader thread is running
- isReadFromSystemAuthUser() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- isReadOnly() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadOnly() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Check if the readOnly flag of the table is set.
- isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- isReadOnly() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns True if region is read only
- isReadOnly() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Helper method to determine if server should only respond to GET HTTP method requests.
- isReadOnly - Variable in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isReadOnly(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether this region replica can accept writes.
- isReadsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isReadSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- isReady() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
Check whether the log splitter is ready to supply tasks
- isReady() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isReady() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
- isReady() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- isReady() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to offline
- isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to online
- isReclaimed() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- isRecovered() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- isRecovered() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns whether this is a replication source for recovery.
- isRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- isRecoveredEdits(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Checks if the given path is the one with 'recovered.edits' dir.
- isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- isReference() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFile
-
Returns True if this is a StoreFile Reference.
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a Reference
- isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isReference(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isReferencedInReads() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Returns true if the file is still used in reads
- isRefOnlyScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Indicates whether it's a reference only scan.
- isRegionCached(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Check the region cache to see whether a region is cached yet or not.
- isRegionCloseMarker() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
Public so can be accessed from regionserver.wal package.
- isRegionCurrentlyWriting(byte[]) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers
-
- isRegionDir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- isRegionDirPresentUnderRoot(TableName, String) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- isRegionInRegionStates(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- isRegionInServerManagerStates(RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isRegionInState(RegionInfo, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- isRegionInTransition(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- isRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Returns True if region is offline (In OFFLINE or CLOSED state).
- isRegionOnline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- isRegionOnline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isRegionOverThreshold(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- isRegionReplicaReplicationEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionReplicaReplicationEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if Region Read Replica is enabled for user-space tables.
- isRegionReplicaStoreFileRefreshEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if we are to refresh user-space hfiles in Region Read Replicas.
- isRegionReplicaWaitForPrimaryFlushEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns True if wait for primary to flush is enabled for user-space tables.
- isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner.OpenScannerResponse
-
- isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- isRegionServerRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isRegionStale(String, long) - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- isRegionStillOpening(RegionInfo, RegionServerServices) - Static method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- isRegionStillOpening() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- isRegionTwiceOverThreshold(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- isRemote(String) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- isRemote() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
The cause of a ForeignException can be an exception that was generated on a local in process
thread, or a thread from a 'remote' separate process.
- isReplay() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- isReplicaGet(Row) - Static method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- isReplicasForSameRegion(RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isReplicationForBulkLoadDataEnabled - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- isReplicationForBulkLoadDataEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- isRequired(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- isRescanNode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- isRescanNode(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
Checks if the given path represents a rescan node.
- isReservedFileInfoKey(byte[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Return true if the given file info key is reserved for internal use.
- isReservoirEnabled() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isRestoredRegion - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isRestoringTable(TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Verify if the restore of the specified table is in progress.
- isRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- isRetryDespiteFastFailMode() - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- isRetryImmediatelySupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- isRetryImmediatelySupported() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
Returns current setting for returnResults
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
-
Returns current setting for returnResults
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Returns current value for returnResults
- isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- isReverse() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- isReversed() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a reversed one.
- isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
-
- isReversed() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- isRIT(AssignmentManager) - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- isRollbackSupported(MasterProcedureProtos.RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- isRollbackSupported(MasterProcedureProtos.MergeTableRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- isRollbackSupported(MasterProcedureProtos.RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- isRollbackSupported(MasterProcedureProtos.SplitTableRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- isRollbackSupported(MasterProcedureProtos.RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- isRollbackSupported(MasterProcedureProtos.CloneSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- isRollbackSupported(MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- isRollbackSupported(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- isRollbackSupported(MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- isRollbackSupported(MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- isRollbackSupported(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- isRollbackSupported(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- isRollbackSupported(MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- isRollbackSupported(MasterProcedureProtos.ModifyTableDescriptorState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- isRollbackSupported(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- isRollbackSupported(MasterProcedureProtos.RestoreSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- isRollbackSupported(MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- isRollbackSupported(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Used by the default implementation of abort() to know if the current state can be aborted and
rollback can be triggered.
- isRollbackSupported(MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- isRollingback() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- isRollRequested() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
-
- isRootFinished(Procedure<?>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This is vestigial API.
- isRpcRef() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- isRPCRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isRPCRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active RPC call.
- isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Get if the rpc throttle is enabled.
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isRpcThrottleEnabled(RpcController, MasterProtos.IsRpcThrottleEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isRpcThrottleEnabled(RpcController, MasterProtos.IsRpcThrottleEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isRpcThrottleEnabled(MasterProtos.IsRpcThrottleEnabledRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
- isRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isRSGroupsEnabled(Connection) - Static method in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- isRunnable() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns true if the procedure is in a RUNNABLE state.
- isRunning() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isRunning() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
When running, the HBCK report may be changed later.
- isRunning() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Returns if the master is currently running and is not attempting to shutdown.
- isRunning() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.FsUtilsLeaseRecovery
-
- isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isRunning() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- isRunning() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Returns true if the store is running, otherwise false.
- isRunning() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- isRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns true
if this service is RUNNING.
- isRunning() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- isRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- isSafePointAttained() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Returns if the safepoint has been attained.
- isSameAddress(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
Compare two addresses
- isSameHdfs(Configuration, FileSystem, FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- isSameServer(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.MoveWithAck
-
Returns true if passed region is still on serverName when we look at hbase:meta.
- isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
-
Returns True if collection of scan metrics is enabled.
- isScanRequest(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- isScanUsePread() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- isScheduled() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns true when this Chore is scheduled with a ChoreService
- isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
Returns whether the bounding row used for binary-search is inclusive or not.
- isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.ReversedRowRange
-
- isSearchRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- isSecureBulkLoadEndpointAvailable() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication
-
Returns true
when secure authentication is enabled (whether
hbase.security.authentication
is set to "kerberos
").
- isSecurityAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- isSecurityEnabled - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isSecurityEnabled - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not Kerberos authentication is configured for Hadoop.
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Returns the result of UserGroupInformation.isSecurityEnabled()
.
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- isSeekToRow - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- isSequenceIdFile(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Is the given file a region open sequence id file.
- isSerial - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isSerial() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is known to be dead.
- isServerInFailureMap(ServerName) - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- isServerKnownAndOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Returns whether the server is online, dead, or unknown.
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isServerOverloaded(Throwable) - Static method in exception org.apache.hadoop.hbase.HBaseServerException
-
Returns True if the server was considered overloaded when the exception was thrown
- isServerOverloaded() - Method in exception org.apache.hadoop.hbase.HBaseServerException
-
Returns True if server was considered overloaded when exception was thrown
- isServerOverloaded() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
Returns True if the server was considered overloaded when the exception was thrown.
- isServerProcedure(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- isServerStarted() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- isServerUnknown(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is unknown.
- isShared - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
-
- isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
-
- isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- isSharedMem() - Method in class org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
-
- isShift(int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- isShift() - Method in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Returns whether to show HBase Configuration in servlet
- isShowQueueDump(Configuration) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- isShutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the service is shutdown and thus cannot be used anymore
- isShutDown() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isSilence() - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- isSimpleAuthentication() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- isSingleNode() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- isSizeLimit(Store, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
Check periodically to see if a system stop is requested every written bytes reach size limit.
- isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance is able to skip over it's encoded value.
- isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isSkipResetSeqId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Gets whether to skip resetting the sequence id for cells.
- isSkipResetSeqId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- isSloppy() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- isSloppyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- isSloppyMemStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns true if the memstore may need some extra memory space
- isSlowLog - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- isSlowLog() - Method in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- isSlowLogTableEnabled - Variable in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- isSmall() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
Deprecated.
- isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the auto snapshot cleanup based on TTL.
- isSnapshotCleanupEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the auto snapshot cleanup based on TTL.
- isSnapshotCleanupEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isSnapshotCleanupEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isSnapshotCleanupEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isSnapshotCleanupEnabled(RpcController, MasterProtos.IsSnapshotCleanupEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isSnapshotCleanupEnabled(RpcController, MasterProtos.IsSnapshotCleanupEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isSnapshotCleanupEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isSnapshotCleanupEnabled() - Method in class org.apache.hadoop.hbase.zookeeper.SnapshotCleanupTracker
-
Returns the current state of the snapshot auto cleanup based on TTL
- isSnapshotCompleted(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check to see if the snapshot is one of the currently completed snapshots Returns true if the
snapshot exists in the "completed snapshots folder".
- isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
Returns true if the snapshot is corrupted
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified snapshot is done.
- isSnapshotDone(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check if the specified snapshot is done n * @return true if snapshot is ready to be restored,
false if it is still being taken.
- isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isSnapshotFinished(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isSnapshotFinished(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isSnapshotFinished(SnapshotDescription) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isSnapshotOwner(SnapshotDescription, User) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Check if the user is this table snapshot's owner
- isSnapshotSupported - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- isSourceActive() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- isSourceActive() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Returns active or not
- isSpecialException(Throwable) - Static method in class org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
-
- isSplit() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Returns True if has been split and has daughters.
- isSplit() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns True if has been split and has daughters.
- isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if has been split and has daughters.
- isSplit() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
Return whether the region has been split and not online.
- isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplitable(JobContext, Path) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
-
- isSplitable(JobContext, Path) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionInputFormat
-
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the split switch.
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Query the current state of the Split switch.
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isSplitEnabled() - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the split enable flag of the table is true.
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Check if the split enable flag of the table is true.
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Check if the region split enable flag of the table is true.
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- isSplitEnabled() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isSplitOrMergeEnabled(MasterSwitchType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isSplitOrMergeEnabled(RpcController, MasterProtos.IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isSplitOrMergeEnabled(MasterSwitchType) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- isSplitOrMergeOn(MasterSwitchType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- isSplitParent() - Method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if this is a split parent region.
- isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isSplittable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Returns true if region is splittable
- isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingDone(MasterProcedureEnv, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOrOpenedOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingOrSplitOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplitWALFinished(String) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
- isStale() - Method in class org.apache.hadoop.hbase.client.Result
-
Whether or not the results are coming from possibly stale data.
- isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- isStarted(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Return true if the procedure is started.
- isStarted() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
Returns if the Chore
has been started.
- isStarting() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- isStarting() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns Return true
is this service is STARTING (but not yet RUNNING).
- isStarting() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Compare of path component.
- isStartRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
Returns if start row is inclusive.
- isStop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
Returns the current value of exitWorker
- isStop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isStopped - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- isStopped() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Returns true if a stop has been requested.
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.ShutdownHook.DoNothingStoppable
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- isStopped() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- isStopped() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
- isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
-
- isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopping() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- isStopping() - Method in interface org.apache.hadoop.hbase.Server
-
Returns True is the server is Stopping
- isStopRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
Returns if stop row is inclusive.
- isStreamUnsupported() - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
For tests only, returns whether the passed stream is supported
- isStringEquals(String, String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
For replication peer cluster key or endpoint class, null and empty string is same.
- isStuck() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- isSubDirectoryOf(Path, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Determines if the given workingDir is a subdirectory of the given "root directory"
- isSuccess() - Method in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
Returns Whether the CheckAndMutate operation is successful or not
- isSuccess() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns true if the procedure is finished successfully.
- isSuccessfulScan(RegionInfo) - Method in class org.apache.hadoop.hbase.util.MoveWithAck
-
Tries to scan a row from passed region
- issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isSuperUser(User) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Check if the current user is a super user
- isSuperUser(String) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Check if the current user is a super user
- isSuperUserId(String[], Id) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- isSuspended() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- isSwitchEnabled() - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker.SwitchStateTracker
-
Return true if the switch is on, false otherwise
- isSyncAborted() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- isSystemOrSuperUser() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- isSystemTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Returns true if this region is from a system table
- isSystemTable() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- isSystemTable - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
-
- isSystemTablesOnlyOnMaster(Configuration) - Static method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
- isTableAssigned() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is available.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is available.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Use this api to check if the table has been created with the specified number of splitkeys
which was used while creating the given table.
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isTableAvailable(TableName, Optional<byte[][]>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isTableAvailable(TTableName) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isTableAvailableAndInitialized() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
This method checks if the namespace table is assigned and then tries to create its Table
reference.
- isTableAvailableWithSplit(TTableName, List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isTableCFsEqual(Map<TableName, List<String>>, Map<TableName, List<String>>) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- isTableDir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- isTableDir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Check whether we have a valid TableDescriptor.
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is disabled.
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is disabled.
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Check if a table is disabled.
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionUtils.MasterlessConnection
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isTableDisabled(TableStateManager, TableName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- isTableDisabled(RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
Returns True if table is disabled or disabling; defaults false!
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isTableDisabled(TTableName) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check if the specified region's table is disabled.
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check if a table is enabled.
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Check if a table is enabled.
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
A table that isTableEnabled == false and isTableDisabled == false is possible.
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- isTableEnabled(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- isTableEnabled() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- isTableEnabled(TTableName) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- isTableEndRow(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- isTableEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- isTableIncluded(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Only check/fix tables specified by the list, Empty list means all tables are included.
- isTableNamespaceManagerInitialized() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- isTableNotFoundException(Throwable) - Static method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- isTableProcedure(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isTablesOnMaster(Configuration) - Static method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
- isTableStartRow(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- isTableState(TableName, TableState.State...) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- isTableTransition(RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
Returns True iff first row in hbase:meta or if we've broached a new table in hbase:meta
- isTagsLenZero - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
Returns true if tags are present in this snapshot
- isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- isTakingAnySnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
The snapshot operation processing as following:
1.
- isTakingSnapshot(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check to see if there is a snapshot in progress with the same name or on the same table.
- isTakingSnapshot(TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check to see if the specified table has a snapshot in progress.
- isTcpNoDelay() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- isTerminated() - Method in class org.apache.hadoop.hbase.ChoreService
-
Returns true when the service is shutdown and all threads have terminated
- isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Text encoding, false otherwise.
- isTimeLimit(Store, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
Check periodically to see if a system stop is requested every time.
- isToBeExpanded(List<ExpressionNode>) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionExpander
-
- isTooManyStoreFiles(Region) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- isTop() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- isTopReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Returns True if the store file is a top Reference
- isTraceEnabled() - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
The procedure could be restarted from a different machine.
- isTraceEnabled() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
The procedure could be restarted from a different machine.
- isTraceEnabled() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
The procedure could be restarted from a different machine.
- isTrackingMetrics() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- isTunerOn() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- isUnassignable() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that can't transition to pending_close/closing
(unassign/offline)
- isUnassignable(RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that can't transition to pending_close/closing
(unassign/offline)
- isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- isUnderCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Check if this store is under compaction
- isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- isUnderline() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- isUnflushedEntries() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- isUninstantiated() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isUnix() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is unix.
- isUnpacked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return true when this block's buffer has been unpacked, false otherwise.
- isUsecache() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- isUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isUsePread() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- isUserReferenced(UserGroupInformation) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- isUserRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- isUsingL0Flush() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- isValid() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- isValid() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- isValid() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- isValid() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
Called on store load by the ProcedureExecutor to validate the procedure stack.
- isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return if the specified file is a valid store file or not.
- isValidArguements(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
- isValidAuthChar(byte) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- isValidHour(int) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- isValidLabel(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- isValidMetaPath(String) - Method in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Helper to check if the given 'path' corresponds to a meta znode.
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
-
- isValidProtocol(String) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
-
- isValidRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- isValidState(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- isValidTime(long) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Return true if time is earlier or equal to current time
- isValidType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
True to indicate that the byte b is a valid type.
- isValidWALRootDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- isVisibilityTagsPresent(Cell) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- isWaiting() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Returns true if the procedure is waiting for a child to finish or for an external event.
- isWaiting() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- isWaitingQueueEmpty() - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- isWithinDefaultWorkingDir(Path, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Determines if the given workingDir is a subdirectory of the default working snapshot directory
- isWorkerRunning() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- isWriteRequest(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- isWriteSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Returns true if a block is being written
- isYieldAfterExecutionStep(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
By default, the procedure framework/executor will try to run procedures start to finish.
- isYieldAfterExecutionStep(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- isYieldBeforeExecuteFromState(TEnvironment, TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
By default, the executor will try ro run all the steps of the procedure start to finish.
- isZeroLengthThenDelete(FileSystem, FileStatus, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
make sure have been through lease recovery before get file status, so the file length can be
trusted.
- itemAllocationSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- itemBeginPos - Variable in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- itemCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- items - Variable in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- itemSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
- itemSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
This bucket size can only allocate items of this size, even if the requested allocation size
is smaller.
- iter - Variable in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- Iter() - Constructor for class org.apache.hadoop.hbase.quotas.QuotaRetriever.Iter
-
- iter - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- iter - Variable in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- iter - Variable in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- iterateOnSplits(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range, splitting at an [a,b) boundary.
- iterateOnSplits(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range.
- iteration - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.CompactionChecker
-
- iterations - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- iterator() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.ListRowAccess
-
- iterator() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- iterator() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
- iterator() - Method in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- iterator() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- iterator() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- iterator() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns Iterator over the blocks in the cache.
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser.Results
-
- iterator() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- iterator() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- iterator() - Method in class org.apache.hadoop.hbase.RegionLocations
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.KeyBeforeConcatenatedLists
-
- Iterator() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator
-
- iterator() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- iterator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- iterator() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
Retrieve an
Iterator
over the values encoded in
src
.
- iterator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- Iterator() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- iterator() - Method in class org.apache.hadoop.hbase.util.SortedList
-
- iterNext - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
-
- iterPrev - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
-
- iv - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- iv - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- iv - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- iv - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- iv - Variable in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Initialization vector
- iv - Variable in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec.EncryptedKvDecoder
-
- iv - Variable in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec.EncryptedKvEncoder
-
- IV_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
-
- m_endRow - Variable in class org.apache.hadoop.hbase.mapred.TableSplit
-
- m_mutator - Variable in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- m_regionLocation - Variable in class org.apache.hadoop.hbase.mapred.TableSplit
-
- m_startRow - Variable in class org.apache.hadoop.hbase.mapred.TableSplit
-
- m_tableName - Variable in class org.apache.hadoop.hbase.mapred.TableSplit
-
- machineQuotaFactor - Variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- magic - Variable in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- MAGIC - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- MAGIC_LENGTH - Static variable in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- MAGIC_SIZE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.chaos.ChaosService
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.ExportEndpointExample
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
For debugging.
- main(String[]) - Static method in class org.apache.hadoop.hbase.hbtop.HBTop
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.http.HtmlQuoting
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
-
A command line implementation
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Test things basically work.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
-
nn
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
-
nn
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Driver
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
Pass table name as argument.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
For testing against a cluster.
- main(String[]) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.region.WALProcedurePrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
Parses a directory of WALs building up ProcedureState.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Code to help figure if our approximation of object heap sizes is close enough.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Main to test basic functionality.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Pass one or more log file names and it will either dump out a text version on
stdout
or split the specified log files.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
Command line tool to compress and uncompress WALs.
- main(String[]) - Static method in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
Main nn
- main(String[]) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.rest.RESTServer
-
The main method for the HBase rest server.
- main(String[]) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift2.DemoClient
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
Start up the Thrift2 server.
- main(String[]) - Static method in class org.apache.hadoop.hbase.tool.BulkLoadHFilesTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.GetJavaProperty
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseConfTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Main program nn
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
Compute the hash of the specified file
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
Simple 'main' to facilitate manual testing of the pause monitor.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.Random64
-
Random64 is a pseudorandom algorithm(LCG).
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionMover
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
The main function for the RegionSplitter application.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMainServer
-
Run the tool.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
Run the tool.
- main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- main(String[]) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- mainLoop() - Method in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- MAINTENANCE_MODE - Static variable in class org.apache.hadoop.hbase.master.HMaster
-
- MaintenanceLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
a balancer which is only used in maintenance mode.
- MaintenanceLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- maintenanceMode - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- major - Variable in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- MAJOR_COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_INPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_INPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_OUTPUT_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTED_OUTPUT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_DROP_CACHE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- MAJOR_COMPACTION_INPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_INPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_INPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_INPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_JITTER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name and default value for major compaction jitter.
- MAJOR_COMPACTION_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Major compaction flag in FileInfo
- MAJOR_COMPACTION_OUTPUT_FILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_OUTPUT_FILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_OUTPUT_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_OUTPUT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name and default value for how often a region should perform a major compaction
- MAJOR_COMPACTION_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_COMPACTION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAJOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
-
- majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table.
- majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table.
- majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within a table.
- majorCompact(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- majorCompact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a table.
- majorCompact(TableName, byte[], CompactType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- majorCompact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- majorCompact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table.
- majorCompact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a table.
- majorCompact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- majorCompact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- majorCompact(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompact(TableName, CompactType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompact(TableName, byte[], CompactType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompactedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- majorCompactedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- majorCompactedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- majorCompactedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- majorCompactedInputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactedInputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompactedOutputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactedOutputBytes - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompaction - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- majorCompactionCompression - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- majorCompactionInputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactionInputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompactionInputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactionInputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompactionJitter - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- majorCompactionOutputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactionOutputFileCountHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompactionOutputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactionOutputSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- majorCompactionPeriod - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- MajorCompactionRequest - Class in org.apache.hadoop.hbase.util.compaction
-
- MajorCompactionRequest(Connection, RegionInfo) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- MajorCompactionRequest(Connection, RegionInfo, Set<String>) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- MajorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for major compaction.
- MajorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
-
- majorCompactionTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- majorCompactionTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- MajorCompactionTTLRequest - Class in org.apache.hadoop.hbase.util.compaction
-
This request helps determine if a region has to be compacted based on table's TTL.
- MajorCompactionTTLRequest(Connection, RegionInfo) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
-
- MajorCompactor - Class in org.apache.hadoop.hbase.util.compaction
-
- MajorCompactor() - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- MajorCompactor(Configuration, TableName, Set<String>, int, long, long) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- MajorCompactor.Compact - Class in org.apache.hadoop.hbase.util.compaction
-
- MajorCompactorTTL - Class in org.apache.hadoop.hbase.util.compaction
-
This tool compacts a table's regions that are beyond it's TTL.
- MajorCompactorTTL(Configuration, TableDescriptor, int, long) - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- MajorCompactorTTL() - Constructor for class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- majorCompactPriority - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.CompactionChecker
-
- majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a table or an individual region.
- majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact a column family within region.
- majorCompactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a region.
- majorCompactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Major compact a column family within region.
- majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Major compact all regions on the region server.
- majorCompactRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Compact all regions on the region server.
- majorCompactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- majorCompactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- majorCompactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- majorCompactRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- majorInProgress - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- majorRangeFromIndex - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- majorRangeFromRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- majorRangeFromRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor.StripeInternalScannerFactory
-
- majorRangeToIndex - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- majorRangeToRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- majorRangeToRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor.StripeInternalScannerFactory
-
- majorVersion - Variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
The
HFile
format major version.
- makeColumn(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Makes a column in family:qualifier form from separate byte arrays.
- makeDeleteFromRegionInfo(RegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a Delete containing the region info for the catalog table
- makeException(boolean) - Method in class org.apache.hadoop.hbase.client.BatchErrors
-
- makeException(List<RetriesExhaustedWithDetailsException>) - Static method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- makeFamilyMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- makeFamilyMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- makeFilter(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
converts quotafilter to serializeable filterlists.
- makeGet(Map.Entry<Key, Value>) - Method in interface org.apache.hadoop.hbase.quotas.QuotaCache.Fetcher
-
- makeGetForNamespaceQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeGetForRegionServerQuotas(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeGetForSnapshotSize(TableName, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Get
for the HBase snapshot's size against the given table.
- makeGetForTableQuotas(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeGetForUserQuotas(String, Iterable<TableName>, Iterable<String>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makePut(RegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- makePutForReplicationBarrier(RegionInfo, long, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- makePutFromRegionInfo(RegionInfo, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Generates and returns a Put containing the region into for the catalog table
- makePutFromTableState(TableState, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Construct PUT for given state
- makeQuotaSnapshotGetForTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeQuotaSnapshotScan() - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Creates a
Scan
which returns only quota snapshots from the quota table.
- makeQuotaSnapshotScanForTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeScan(QuotaFilter) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- makeStub() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceStubMaker
-
Create a stub against the master.
- makeStubNoRetries() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceStubMaker
-
Create a stub.
- makeZKProps(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Make a Properties object holding ZooKeeper config.
- makeZKPropsFromHbaseConfig(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Make a Properties object holding ZooKeeper config.
- manageError(int, Row, AsyncRequestFutureImpl.Retry, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Check that we can retry acts accordingly: logs, set the error status.
- manageLocationError(Action, Exception) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- manager - Variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- manager - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- manager - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- MANIFEST_FILE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- ManifestBuilder(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- ManifestBuilder(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- manifestSizeLimit - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- ManualEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
An environment edge that uses a manually set value.
- ManualEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- ManualMobMaintHFileCleaner - Class in org.apache.hadoop.hbase.mob
-
BaseHFileCleanerDelegate
that prevents cleaning HFiles from a mob region keeps a map of
table name strings to mob region name strings over the life of a JVM instance.
- ManualMobMaintHFileCleaner() - Constructor for class org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
-
- map - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- map - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- map - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Pass the key, value to reduce nnnnn
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, Text, LongWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
Maps the data.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Pass the key, value to reduce.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, Import.CellWritableComparable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
Deprecated.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, Import.KeyValueWritableComparable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
-
Deprecated.
- Map() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
Map method that compares every scanned row with the equivalent from a distant cluster.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterMapper
-
Maps the data.
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SampleUploader.Uploader
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Convert a line of TSV text into an HBase table row.
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Convert a line of TSV text into an HBase table row.
- map(WALKey, WALEdit, Mapper<WALKey, WALEdit, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALCellMapper
-
- map(WALKey, WALEdit, Mapper<WALKey, WALEdit, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALKeyValueMapper
-
Deprecated.
- map(WALKey, WALEdit, Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- map - Variable in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, Text, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper
-
- map - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- map - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- map(LongWritable, Text, Mapper<LongWritable, Text, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- map - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- map(BytesWritable, NullWritable, Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- map - Variable in class org.apache.hadoop.hbase.util.IdLock
-
- MAP_COMPARATOR - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- MAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for entry in map
- mapClass - Variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
- mapField - Variable in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
-
- mapFileReader - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
- mapHostNameToServerName(List<String>) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
Map hostname to ServerName, The output ServerName list will have the same order as input hosts.
- mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array suitable for use as a key in maps.
- mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Calculate a hash code from a given byte array suitable for use as a key in maps.
- mapper - Variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.MapRunner
-
- MAPPER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
- MAPPER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- mapperException - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- mappers - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- MAPPERS - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- MAPREDUCE_INPUT_AUTOBALANCE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Specify if we enable auto-balance to set number of mappers in M/R jobs.
- MapreduceDependencyClasspathTool - Class in org.apache.hadoop.hbase.util
-
Generate a classpath string containing any jars required by mapreduce jobs.
- MapreduceDependencyClasspathTool() - Constructor for class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- MapReduceExtendedCell - Class in org.apache.hadoop.hbase.util
-
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
- MapReduceExtendedCell(Cell) - Constructor for class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- mapRSToPrimaries(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- MapRunner(Mapper<ImmutableBytesWritable, Result, K2, V2>.Context) - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.MapRunner
-
- mark(int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- mark() - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- mark(long) - Method in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- mark() - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Records one occurrence.
- mark(long) - Method in interface org.apache.hadoop.hbase.metrics.Meter
-
Records events
occurrences.
- mark() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Marks the current position of the ByteBuff
- mark() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Marks the current position of the MBB
- mark() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- markAsEvicted() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
The
BucketCache
will try to release its reference to this BucketEntry many times.
- markCompactedAway() - Method in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- markCompactedAway(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- markComplete(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- markComplete(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- markComplete(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- markCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
-
- markCorrupted(Path, String, FileSystem) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
marks log file as corrupted
- markCorrupted(Path, String, FileSystem) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- markCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Deprecated.
- markCorruptedWAL(ProcedureWALFile, IOException) - Method in interface org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.Loader
-
Deprecated.
- markedAsEvicted - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- markedItemIndex - Variable in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- MARKER - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
-
- markFutureDoneAndOffer(SyncFuture, long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
Helper that marks the future as DONE and offers it back to the cache.
- markHead() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- markRegionAsMerged(RegionInfo, ServerName, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
When called here, the merge has happened.
- markRegionAsSplit(RegionInfo, ServerName, RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- markSupported() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- markTableAsDeleted(TableName, Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
Tries to remove the queue and the table-lock of the specified table.
- mask - Variable in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- mask - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- MASK_FOR_LOWER_INT_IN_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Mask to apply to a long to reveal the lower int only.
- MASK_TIMESTAMP_LENGTH - Static variable in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- MASK_TIMESTAMP_LENGTH - Static variable in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- master - Variable in class org.apache.hadoop.hbase.client.MasterCallable
-
- master - Variable in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
- master - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- master - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- master - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- master - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerChore
-
- master - Variable in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- master - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- master - Variable in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
- MASTER - Static variable in class org.apache.hadoop.hbase.master.HMaster
-
- master - Variable in class org.apache.hadoop.hbase.master.locking.LockManager
-
- master - Variable in class org.apache.hadoop.hbase.master.MasterInitializationMonitor
-
- master - Variable in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- master - Variable in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- master - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
-
- master - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.FsUtilsLeaseRecovery
-
- master - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- master - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- master - Variable in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- master - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- master - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- master - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- master - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- master - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- master - Variable in class org.apache.hadoop.hbase.master.SplitWALManager
-
- master - Variable in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- master - Variable in class org.apache.hadoop.hbase.master.TableStateManager
-
- master - Variable in class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- master - Variable in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- master - Variable in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- master - Variable in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- master - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- master - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- master - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- master - Variable in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
- MASTER__META_TRANSITION_HANDLER_COUNT_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_ACTIVE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_ACTIVE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_ADDRS_CONF_SEPARATOR - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_ADDRS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the list of master host:ports
- MASTER_CHECK_COMPRESSION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- MASTER_CHECK_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
- MASTER_CLOSE_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_CLOSE_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_COPROC_METRICS_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- MASTER_COPROC_METRICS_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- MASTER_COPROC_METRICS_JMX_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- MASTER_COPROC_METRICS_NAME - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- MASTER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- MASTER_FINISHED_INITIALIZATION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_FINISHED_INITIALIZATION_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- MASTER_HFILE_CLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- MASTER_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.util.DNS
-
- MASTER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what master implementation to use.
- MASTER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for master web API port
- MASTER_KRB_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
- MASTER_KRB_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
Configuration keys for programmatic JAAS configuration for secured master and regionserver
interaction
- MASTER_LOG_REPLAY_OPS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_LOG_REPLAY_OPS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_MERGE_DISPATCH_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Number of threads used to dispatch merge operations to the regionservers.
- MASTER_MERGE_DISPATCH_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_META_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_META_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_META_TRANSITION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_OPEN_REGION_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configurations for master executor services.
- MASTER_OPEN_REGION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port master listens on.
- MASTER_PROCEDURE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- MASTER_PROCEDURE_LOGDIR - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
Used to construct the name of the log directory for master procedures
- MASTER_PROCEDURE_THREADS - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
-
Number of threads used by the procedure executor
- MASTER_REGISTRY_HEDGED_REQS_FANOUT_KEY - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
Configuration key that controls the fan out of requests
- MASTER_REGISTRY_INITIAL_REFRESH_DELAY_SECS - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_REGISTRY_MIN_SECS_BETWEEN_REFRESHES - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_REGISTRY_PERIODIC_REFRESH_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MASTER_RPC_SCHEDULER_FACTORY_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
RPC scheduler to use for the master.
- MASTER_SCP_RETAIN_ASSIGNMENT - Static variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Configuration parameter to enable/disable the retain region assignment during
ServerCrashProcedure.
- MASTER_SERVER_OPERATIONS_THREADS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_SERVER_OPERATIONS_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_SERVER_REPORT_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
Set RSReport requests handlers count when masters use MasterFifoRpcScheduler.
- MASTER_SNAPSHOT_TIMEOUT_MILLIS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- MASTER_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MASTER_STORE_DIR - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the master type being backup (waits for primary to go inactive).
- masterActiveTime - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- masterAddressSyncer - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MasterAddressSyncer - Class in org.apache.hadoop.hbase.master.zksyncer
-
Tracks the active master address on server ZK cluster and synchronize them to client ZK cluster
if changed
- MasterAddressSyncer(ZKWatcher, ZKWatcher, Server) - Constructor for class org.apache.hadoop.hbase.master.zksyncer.MasterAddressSyncer
-
- masterAddressTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MasterAddressTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Manages the location of the current active Master for the RegionServer.
- MasterAddressTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Construct a master address listener with the specified zookeeper
reference.
- masterAddressZNode - Variable in class org.apache.hadoop.hbase.master.zksyncer.MasterAddressSyncer
-
- masterAddressZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- MasterAnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.master
-
Priority function specifically for the master.
- MasterAnnotationReadingPriorityFunction(RSRpcServices) - Constructor for class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
-
- MasterAnnotationReadingPriorityFunction(RSRpcServices, Class<? extends RSRpcServices>) - Constructor for class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
-
- MasterCallable<V> - Class in org.apache.hadoop.hbase.client
-
A RetryingCallable for Master RPC operations.
- MasterCallable(Connection, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.MasterCallable
-
- masterClass - Variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- masterClass - Variable in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- MasterCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
-
- MasterCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- MasterCoprocessorHost - Class in org.apache.hadoop.hbase.master
-
Provides the coprocessor framework and environment for master oriented operations.
- MasterCoprocessorHost(MasterServices, Configuration) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- MasterCoprocessorHost.MasterEnvironment - Class in org.apache.hadoop.hbase.master
-
Coprocessor environment extension providing access to master related services.
- MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors - Class in org.apache.hadoop.hbase.master
-
Special version of MasterEnvironment that exposes MasterServices for Core Coprocessors only.
- MasterCoprocessorHost.MasterObserverOperation - Class in org.apache.hadoop.hbase.master
-
- masterCoprocessorNames - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- masterCoprocessorNames - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- MasterCoprocessorRpcChannelImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of a master based coprocessor rpc channel.
- MasterCoprocessorRpcChannelImpl(AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<Message>) - Constructor for class org.apache.hadoop.hbase.client.MasterCoprocessorRpcChannelImpl
-
- MasterCoprocessorService(CoprocessorService) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.MasterCoprocessorService
-
Deprecated.
- MasterDDLOperationHelper - Class in org.apache.hadoop.hbase.master.procedure
-
Helper class for schema change procedures
- MasterDDLOperationHelper() - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
- MasterDumpServlet - Class in org.apache.hadoop.hbase.master.http
-
- MasterDumpServlet() - Constructor for class org.apache.hadoop.hbase.master.http.MasterDumpServlet
-
- MasterEnvironment(MasterCoprocessor, int, int, Configuration, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- MasterEnvironmentForCoreCoprocessors(MasterCoprocessor, int, int, Configuration, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors
-
- MasterFeature - Class in org.apache.hadoop.hbase.master.http.jersey
-
- MasterFeature(HMaster) - Constructor for class org.apache.hadoop.hbase.master.http.jersey.MasterFeature
-
- MasterFeature.Binder - Class in org.apache.hadoop.hbase.master.http.jersey
-
Register this feature's provided functionality and defines their lifetime scopes.
- MasterFifoRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
A special RpcScheduler} only used for master.
- MasterFifoRpcScheduler(Configuration, int, int) - Constructor for class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- MasterFifoRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
- MasterFifoRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
-
- MasterFileSystem - Class in org.apache.hadoop.hbase.master
-
This class abstracts a bunch of operations the HMaster needs to interact with the underlying file
system like creating the initial layout, checking file system status, etc.
- MasterFileSystem(Configuration) - Constructor for class org.apache.hadoop.hbase.master.MasterFileSystem
-
- masterFinishedInitializationTime - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MasterFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
-
- MasterFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- masterInfoPort - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- masterInfoPort - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- MasterInitializationMonitor - Class in org.apache.hadoop.hbase.master
-
Protection against zombie master.
- MasterInitializationMonitor(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MasterInitializationMonitor
-
Creates a Thread that monitors the #isInitialized()
state.
- masterJettyServer - Variable in class org.apache.hadoop.hbase.master.HMaster
-
jetty server for master to redirect requests to regionserver infoServer
- MasterKeepAliveConnection - Interface in org.apache.hadoop.hbase.client
-
A KeepAlive connection is not physically closed immediately after the close, but rather kept
alive for a few minutes.
- masterless - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
True if this RegionServer is coming up in a cluster where there is no Master; means it needs to
just come up and make do without a Master to talk to: e.g.
- MASTERLESS_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MasterlessConnection(Configuration, ExecutorService, User) - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils.MasterlessConnection
-
- masterLock - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- MasterLock(String, LockType, String) - Constructor for class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- MasterLock(TableName, LockType, String) - Constructor for class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- MasterLock(RegionInfo[], String) - Constructor for class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- MasterMaintenanceModeTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the master Maintenance Mode via ZK.
- MasterMaintenanceModeTracker(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
-
- masterMaintZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- masterName - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- masterName - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- masterName - Variable in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
-
- MasterNotRunningException - Exception in org.apache.hadoop.hbase
-
Thrown if the master is not running
- MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
default constructor
- MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor
- MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor taking another exception.
- MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
- MasterObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines coprocessor hooks for interacting with operations on the
HMaster
process.
- masterObserverGetter - Variable in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- MasterObserverOperation() - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterObserverOperation
-
- MasterObserverOperation(boolean) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterObserverOperation
-
- MasterObserverOperation(User) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterObserverOperation
-
- MasterObserverOperation(User, boolean) - Constructor for class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterObserverOperation
-
- MasterProcedureConstants - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureConstants() - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
-
- MasterProcedureEnv - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureEnv(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- MasterProcedureEnv(MasterServices, RSProcedureDispatcher) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- MasterProcedureEnv.FsUtilsLeaseRecovery - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
A life-cycle management interface for globally barriered procedures on master.
- MasterProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
- MasterProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
-
Provides the globally barriered procedure framework and environment for master oriented
operations.
- MasterProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- MasterProcedureScheduler - Class in org.apache.hadoop.hbase.master.procedure
-
ProcedureScheduler for the Master Procedures.
- MasterProcedureScheduler(Function<Long, Procedure<?>>) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- MasterProcedureUtil - Class in org.apache.hadoop.hbase.master.procedure
-
- MasterProcedureUtil() - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
- MasterProcedureUtil.NonceProcedureRunnable - Class in org.apache.hadoop.hbase.master.procedure
-
Helper Runnable used in conjunction with submitProcedure() to deal with submitting procs with
nonce.
- masterProcSource - Variable in class org.apache.hadoop.hbase.master.MetricsMaster
-
- masterProcSource - Variable in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
-
- MasterQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Master Quota Manager.
- MasterQuotaManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- MasterQuotaManager.NamedLock<T> - Class in org.apache.hadoop.hbase.quotas
-
- MasterQuotaManager.SetQuotaOperations - Interface in org.apache.hadoop.hbase.quotas
-
Encapsulates CRUD quota operations for some subject.
- MasterQuotaManager.SizeSnapshotWithTimestamp - Class in org.apache.hadoop.hbase.quotas
-
Holds the size of a region at the given time, millis since the epoch.
- MasterQuotasObserver - Class in org.apache.hadoop.hbase.quotas
-
An observer to automatically delete quotas when a table/namespace is deleted.
- MasterQuotasObserver() - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- masterQuotaSource - Variable in class org.apache.hadoop.hbase.master.MetricsMaster
-
- MasterRedirectServlet - Class in org.apache.hadoop.hbase.master.http
-
- MasterRedirectServlet(InfoServer, String) - Constructor for class org.apache.hadoop.hbase.master.http.MasterRedirectServlet
-
- masterRegion - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- masterRegion - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- masterRegion - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MasterRegion - Class in org.apache.hadoop.hbase.master.region
-
A region that stores data in a separated directory, which can be used to store master local data.
- MasterRegion(HRegion, WALFactory, MasterRegionFlusherAndCompactor, MasterRegionWALRoller) - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegion
-
- MasterRegionFactory - Class in org.apache.hadoop.hbase.master.region
-
- MasterRegionFactory() - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- MasterRegionFlusherAndCompactor - Class in org.apache.hadoop.hbase.master.region
-
As long as there is no RegionServerServices for a master local region, we need implement the
flush and compaction logic by our own.
- MasterRegionFlusherAndCompactor(Configuration, Abortable, HRegion, long, long, long, int, Path, String) - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- MasterRegionParams - Class in org.apache.hadoop.hbase.master.region
-
- MasterRegionParams() - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- MasterRegionServerList - Class in org.apache.hadoop.hbase.master
-
- MasterRegionServerList(MasterRegion, Abortable) - Constructor for class org.apache.hadoop.hbase.master.MasterRegionServerList
-
- MasterRegionUtils - Class in org.apache.hadoop.hbase.master.region
-
- MasterRegionUtils() - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegionUtils
-
- MasterRegionWALRoller - Class in org.apache.hadoop.hbase.master.region
-
As long as there is no RegionServerServices for a master local region, we need implement log
roller logic by our own.
- MasterRegionWALRoller(String, Configuration, Abortable, FileSystem, Path, Path, String) - Constructor for class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- MasterRegistry - Class in org.apache.hadoop.hbase.client
-
- MasterRegistry(Configuration) - Constructor for class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
- MasterRegistryFetchException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when an master registry RPC fails in client.
- MasterRegistryFetchException(Set<ServerName>, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException
-
- masterRequest() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- MasterRequestCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- MasterRpcServices - Class in org.apache.hadoop.hbase.master
-
Implements the master RPC services.
- MasterRpcServices(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MasterRpcServices
-
- MasterRpcServices.BalanceSwitchMode - Enum in org.apache.hadoop.hbase.master
-
- masterServerName - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- masterServices - Variable in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- MasterServices - Interface in org.apache.hadoop.hbase.master
-
A curated subset of services provided by
HMaster
.
- masterServices - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.slowlog.SlowLogMasterService
-
- masterServices - Variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- masterServices - Variable in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- masterServices - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- masterServices - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- masterServices - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- masterServices - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- masterServices - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- masterServiceState - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- MasterServiceState(Connection) - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- MasterServiceStubMaker() - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceStubMaker
-
- MasterSnapshotVerifier - Class in org.apache.hadoop.hbase.master.snapshot
-
General snapshot verification on the master.
- MasterSnapshotVerifier(MasterServices, SnapshotProtos.SnapshotDescription, FileSystem) - Constructor for class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
- masterSource - Variable in class org.apache.hadoop.hbase.master.MetricsMaster
-
- masterSource - Variable in enum org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl.FactoryStorage
-
- MasterStatusServlet - Class in org.apache.hadoop.hbase.master.http
-
The servlet responsible for rendering the index page of the master.
- MasterStatusServlet() - Constructor for class org.apache.hadoop.hbase.master.http.MasterStatusServlet
-
- MasterStoppedException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the master is stopped
- MasterStoppedException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MasterStoppedException
-
- masterStub - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- masterStubMakeFuture - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- MasterSwitchType - Enum in org.apache.hadoop.hbase.client
-
Represents the master switch type
- MasterSwitchType() - Constructor for enum org.apache.hadoop.hbase.client.MasterSwitchType
-
- masterSystemTime - Variable in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- masterSystemTime - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- masterSystemTime - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- masterSystemTime - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- masterSystemTime - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- masterTasks - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- masterTasks - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- MasterThread(HMaster, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
- masterThreads - Variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- MasterWalManager - Class in org.apache.hadoop.hbase.master
-
This class abstracts a bunch of operations the HMaster needs when splitting log files e.g.
- MasterWalManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterWalManager
-
- MasterWalManager(Configuration, FileSystem, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MasterWalManager
-
- masterWrapper - Variable in class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
-
- masterWrapper - Variable in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
-
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Determines if the caller should do one of several things:
seek/skip to the next row (MatchCode.SEEK_NEXT_ROW)
seek/skip to the next column (MatchCode.SEEK_NEXT_COL)
include the current KeyValue (MatchCode.INCLUDE)
ignore the current KeyValue (MatchCode.SKIP)
got to the next row (MatchCode.DONE)
- match(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
-
- matchAndRemoveSuffixFromPipeline(List<? extends Segment>) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- MatchCode() - Constructor for enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
- matchColumn(Cell, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- matcher - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- matches(Region, ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- matches(CompareOperator, int) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- matches(RegionState.State...) - Method in enum org.apache.hadoop.hbase.master.RegionState.State
-
- matches(CompareOperator, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- matches(String) - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- matchingColumn(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingColumn(Cell, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingColumn(Cell, byte, int, Cell, byte, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingColumn(Cell, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingColumnFamilyAndQualifierPrefix(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns True if matching column family and the qualifier starts with qual
- matchingFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, byte, Cell, byte) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingQualifier(Cell, int, Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingQualifier(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Finds if the qualifier part of the cell and the KV serialized byte[] are equal.
- matchingQualifier(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingQualifier(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Finds if the qualifier part of the cell and the KV serialized byte[] are equal
- matchingRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRow(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRow(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRowColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row and column of two keyvalues for equality
- matchingRowColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the row and column of two keyvalues for equality
- matchingRowColumnBytes(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row and column of two keyvalues for equality
- matchingRows(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRows(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row of two keyvalues for equality
- matchingRows(Cell, short, Cell, short) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Compares the row of two keyvalues for equality
- matchingRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the row of two keyvalues for equality
- matchingRows(Cell, short, Cell, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compares the row of two keyvalues for equality
- matchingRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Deprecated.
Compare rows.
- matchingRows(Cell, byte[], int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingTags(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingTags(Cell, Cell, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingTimestamp(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingType(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingType(Cell, Cell) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingValue(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingValue(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingValue(Cell, Cell, int, int) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
- matchingValue(Tag, Tag) - Static method in interface org.apache.hadoop.hbase.Tag
-
Matches the value part of given tags
- matchOrdinalSortedVisibilityTags(List<Tag>, List<Tag>) - Static method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- matchReplicationScope(boolean) - Method in interface org.apache.hadoop.hbase.client.TableDescriptor
-
Check if the table's cfs' replication scope matched with the replication state
- matchUnSortedVisibilityTags(List<Tag>, List<Tag>) - Static method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- matchVisibility(List<Tag>, Byte, List<Tag>, Byte) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System uses this for deciding whether a Cell can be deleted by matching visibility expression
in Delete mutation and the cell in consideration.
- materializeVersion(int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Create a 4 byte serialized version number by combining the minor and major version numbers.
- max - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
How many blocks to look at before we give up.
- max - Variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- MAX_ALLOC_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- MAX_ALLOC_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- MAX_ALLOWED_FOLD_FACTOR - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Maximum number of times a Bloom filter can be "folded" if oversized
- MAX_ARRAY_SIZE - Static variable in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
- MAX_ARRAY_SIZE - Static variable in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- MAX_ATTEMPTS_FN_GENERATION - Static variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- MAX_AVERAGE_REGION_SIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
In auto-balance, we split input by ave region size, if calculated region size is too big, we
can set it.
- MAX_BACKOFF_KEY - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- MAX_BATCH - Static variable in class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- MAX_BATCH_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- MAX_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- MAX_BUFFER_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- MAX_BYTE_ARRAY - Static variable in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- MAX_CELLS_LENGTH - Static variable in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- MAX_CHALLENGE_SIZE - Static variable in class org.apache.hadoop.hbase.security.SaslChallengeDecoder
-
- MAX_CHUNK_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
The maximum size guideline for index blocks (both leaf, intermediate, and root).
- MAX_COMPACTED_STORE_FILE_REF_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAX_COMPACTION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- MAX_COMPACTION_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- MAX_COMPARATOR_NAME_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
We store the comparator class name as a fixed-length field in the trailer.
- MAX_CONCURRENT_LOCATE_REQUEST_PER_TABLE - Static variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- MAX_COST - Static variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- MAX_DATA_LEN - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- MAX_DEPTH - Static variable in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- MAX_EPOCH - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- MAX_FETCH_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFile
-
- MAX_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The maximum number of files to compact within a stripe; same as for regular compaction.
- MAX_FILES_PER_REGION_PER_FAMILY - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- MAX_FILES_PER_REGION_PER_FAMILY - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes the maximum size
of the store file after which a region split occurs.
- MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- MAX_FILESIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- MAX_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
The following MAX_FLUSH_PER_CHANGES is large enough because each KeyValue has 20+ bytes
overhead.
- MAX_FLUSH_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- MAX_FLUSH_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- MAX_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum supported HFile format version
- MAX_FRAME_SIZE_CONF_DEFAULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- MAX_FRAME_SIZE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- MAX_IDLETIME - Static variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- MAX_IDLETIME - Static variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- MAX_KEYVALUE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- MAX_KEYVALUE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- MAX_LOG_FILTERS - Static variable in class org.apache.hadoop.hbase.filter.FilterListBase
-
- MAX_LOG_PREFIXES - Static variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- MAX_LOG_TIMESTAMPS - Static variable in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- MAX_LOGS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- MAX_MEMSTORE_TS_KEY - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Max memstore (mvcc) timestamp in FileInfo
- MAX_MERGE_COUNT_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- MAX_MERGE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- MAX_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- MAX_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Maximum minor version supported by this HFile format
- MAX_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Maximum minor version supported by this HFile format
- MAX_MOVES_PERCENT_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- MAX_NODE_SIZE - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- MAX_NUM_THREADS - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- MAX_PRECISION - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
Max precision guaranteed to fit into a long
.
- MAX_QUEUE_SIZE_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- MAX_QUEUED_REQUESTS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The maximum number of pending connections waiting in the queue.
- MAX_REGION_SPLIT_IMBALANCE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
When splitting region, the maximum size imbalance to allow in an attempt to split at a stripe
boundary, so that no files go to both regions.
- MAX_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- MAX_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- MAX_REQUEST_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MAX_RETRIES - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- MAX_RETRIES_BEFORE_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- MAX_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max length a row can have because of the limitation in TFile.
- MAX_RUNNING_TIME_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- MAX_SEQ_ID_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Max Sequence ID in FileInfo
- MAX_SERVER_PER_MESSAGE - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
We want to limit the size of the protobuf message sent, do fit into a single packet.
- MAX_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MAX_STEP_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- MAX_STEPS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- MAX_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAX_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAX_STOREFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAX_STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MAX_SYNC_FAILURE_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- MAX_TAG_LENGTH - Static variable in interface org.apache.hadoop.hbase.Tag
-
- MAX_TAGS_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- MAX_TAGS_LENGTH - Static variable in interface org.apache.hadoop.hbase.RawCell
-
- MAX_TASKS_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- MAX_THREADS_NUM - Static variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- MAX_TIER_AGE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
-
- MAX_TRAILER_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- MAX_TYPE - Static variable in class org.apache.hadoop.hbase.util.CellHashKey
-
- MAX_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MAX_VERSIONS_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MAX_WAITING_TIME - Static variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- MAX_WALS_KEY - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- MAX_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The maximum size of the thread pool.
- MAX_WORKERS_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- MAX_ZK_META_FETCH_RETRIES - Static variable in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Maximum number of times we retry when ZK operation times out.
- maxAlloc - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- maxAttempCount - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.PutStatus
-
Deprecated.
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BuilderBase
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- maxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- maxAttempts - Variable in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- maxBackoff - Variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- maxBalancingTime - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- maxBlockedRequests - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- maxBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- maxBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- maxBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- maxBufCount - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- maxBusyWaitDuration - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- maxBusyWaitMultiplier - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- maxBytesPerSec - Variable in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- maxCacheSize - Variable in class org.apache.hadoop.hbase.CacheEvictionStats
-
- maxCacheSize - Variable in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
-
- maxCacheSize - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- maxCacheSize - Variable in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- maxCapacity - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- maxCellIdx - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- maxCellSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- maxChunkSize - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The maximum size guideline of all multi-level index blocks.
- maxColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- maxColumn - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- maxColumnCount - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- maxColumnInclusive - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- maxCompactedStoreFileRefCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- maxCompactedStoreFileRefCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- maxCompactedStoreFileRefCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- maxCompactionQueueSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- maxCompactSize - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
Since all these properties can change online, they are volatile
- maxCompressedLength(int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- maxCompressedLength(int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- maxCompressedLength(int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- maxCompressedLength(int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- maxCompressedLength(int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- maxCompressedLength(int) - Static method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- maxConcurrentCallsPerServer - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- maxConcurrentLocateRequestPerTable - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- maxConcurrentTasks - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- maxConcurrentTasksPerRegion - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
The number of tasks we run in parallel on a single region.
- maxConcurrentTasksPerRegion - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- maxConcurrentTasksPerServer - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
The number of task simultaneously executed on a single region server.
- maxConcurrentTasksPerServer - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- maxCopyThreads - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- maxCost - Variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- maxCount - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- maxDataLen - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- maxDelay - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor.CallPriorityComparator
-
- maxDispersionNum - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- maxDispersionNumServerSet - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- maxDispersionScore - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- maxDispersionScoreServerSet - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- maxExcludeDNCount - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
- maxFileSize - Variable in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- maxFilesPerRegionPerFamily - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- maxFilesToCompact - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- maxFlushedSeqId - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
The max sequence id of flushed data on this region.
- maxFlushQueueSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- maxFold - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
Maximum fold factor
- maxFrameLength - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- maxHeapSize - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- maxHeapSize - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- maxHeapSize - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- maxHeapSizeMB - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- maxHeapSizePerRequest - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
The maximum heap size for each request.
- maxHeapSizePerRequest - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestHeapSizeChecker
-
- maxHeapSizeSubmit - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
- maxHeapSizeSubmit - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.SubmittedSizeChecker
-
- maxHeapUsage - Variable in class org.apache.hadoop.hbase.wal.EntryBuffers
-
- maxIdleTime - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- maxIdleToClose - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- MAXIMUM_KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Maximum length of key in HFile.
- MAXIMUM_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum value length, enforced on KeyValue construction
- maximumStepSize - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- maximumTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- maximumTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- maxIterationMillis - Variable in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
- maxKeyCount - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Maximum key count after compaction (for blooms)
- maxKeyCount - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- maxKeyCount() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- maxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- maxKeyCount - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
- maxKeys - Variable in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Max Keys expected for the bloom
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- maxKeyValueSize(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the maximum key-value size specified by the provided
Connection
's
Configuration
instance, via the configuration key
hbase.client.keyvalue.maxsize
.
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- maxKeyValueSize - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- maxLatency - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- maxLatency - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- maxLogs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- maxMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- maxMemstoreTS - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- maxMerge - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- maxMergeCount - Variable in class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
Maximum for many regions to merge at a time.
- maxModifiedProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- maxModifiedProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- maxMovesPercent - Variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- maxMultiSize - Variable in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- maxMVCCReadpoint - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Latest memstore read point found in any of the involved files
- maxOverlapsToSideline - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- maxPoolSize - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- maxPoolSizeInfoLevelLogged - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- maxProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- maxProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- maxQueuedRequests - Variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
-
- maxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- maxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
-
- maxQueueSize - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
- maxQueueSize - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- maxQueueSizeInBytes - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Maximum size in bytes of the currently queued and running Calls.
- maxReadPointToTrackVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
readPoint over which the KVs are unconditionally included
- maxRegionsOnRS - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- maxRegionSplitImbalance - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- maxRequestSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- maxResultSize - Variable in class org.apache.hadoop.hbase.client.Scan
-
- maxResultSize - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- maxRetries - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- maxRetries - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- maxRetries - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- maxRetriesBeforeRoll - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- maxRetriesMultiplier - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- maxRetriesMultiplier - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- maxRetriesMultiplier - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- maxRetriesMultiplier - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- maxRetryInQueue - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- maxRitPercent - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- maxRollRetry - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- maxRowBytes - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- maxRowSize - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- maxRowsPerRequest - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
The maximum number of rows for each request.
- maxRowsPerRequest - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestRowsChecker
-
- maxRunningTime - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- maxScannerResultSize - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- maxScannerResultSize - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- maxSeqId - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
The last key in the files we're compacting.
- maxSeqIdInStores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- maxSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- maxSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Maximum allowable size of cache (block put if size > max, evict)
- maxSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Maximum allowable size of cache (block put if size > max, evict)
- maxSize - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
- maxSize - Variable in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- maxSizeBytes - Variable in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
- maxSkew - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- maxSleepTime - Variable in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- maxSplitTasks - Variable in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- maxStamp - Variable in class org.apache.hadoop.hbase.io.TimeRange
-
- maxSteps - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- maxStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- maxStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- maxStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- maxStoreFileCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- maxStoreFileCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- maxSyncFailureRoll - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- maxTagsLength - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- maxTagsLength - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Max tags length
- maxTasks - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- maxTerminationWait - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- maxThreads - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- maxthreads - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- maxthreads - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- maxthreads(int) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set the max number of threads that will be used to move regions
- maxThroughput - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- maxThroughputLowerBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- maxThroughputOffpeak - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
-
- maxThroughputPerOperation - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- maxThroughputUpperBound - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- maxTierAgeCutoff - Variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory.Window
-
Will not promote to next tier for window before it.
- maxTierAgeMillis - Variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
-
- maxTime - Variable in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- maxTotalConcurrentTasks - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController
-
The number of tasks simultaneously executed on the cluster.
- maxTotalConcurrentTasks - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- maxTries - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
- maxValues - Variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- maxVersions - Variable in class org.apache.hadoop.hbase.client.Get
-
- maxVersions - Variable in class org.apache.hadoop.hbase.client.Scan
-
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- maxVersions - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- maxVersions - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- maxVersions - Variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- maxWaitTime - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- maxWals - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- maxWals(int) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- maxWals() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- maybeCloneWithAllocator(MutableSegment, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
If the segment has a memory allocator the cell is being cloned to this space, and returned;
Otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it
is not allocated on MSLAB.
- maybeCloneWithAllocator(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
If the segment has a memory allocator the cell is being cloned to this space, and returned;
otherwise the given cell is returned
- maybeCloneWithAllocator(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
If the segment has a memory allocator the cell is being cloned to this space, and returned;
otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it
is not allocated on MSLAB.
- maybeRecord() - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- maybeRecord(Object) - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- maybeWrapFileSystem(FileSystem, Configuration) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns an instance of Filesystem wrapped into the class specified in hbase.fs.wrapper
property, if one is set in the configuration, returns unmodified FS instance passed in as an
argument otherwise.
- mayHaveClusterIssues() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- mayHaveMoreCellsInRow - Variable in class org.apache.hadoop.hbase.client.Result
-
- mayHaveMoreCellsInRow() - Method in class org.apache.hadoop.hbase.client.Result
-
For scanning large rows, the RS may choose to return the cells chunk by chunk to prevent OOM or
timeout.
- mayHaveMoreCellsInRow() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- MB_IN_BYTES - Static variable in class org.apache.hadoop.hbase.HConstants
-
- mBeanServer - Variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
MBean server.
- MBeanSource - Interface in org.apache.hadoop.hbase.metrics
-
Object that will register an mbean with the underlying metrics implementation.
- MBeanSourceImpl - Class in org.apache.hadoop.hbase.metrics
-
Hadoop2 metrics2 implementation of an object that registers MBeans.
- MBeanSourceImpl() - Constructor for class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
-
- mbServer - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- md - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- md - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- MD5_HEX_LENGTH - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- MD5Hash - Class in org.apache.hadoop.hbase.util
-
Utility class for MD5 MD5 hash produces a 128-bit digest.
- MD5Hash() - Constructor for class org.apache.hadoop.hbase.util.MD5Hash
-
- MEAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- measure(TimeMeasurable<T>) - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Measure elapsed time of a measurable method.
- measure() - Method in interface org.apache.hadoop.hbase.util.TimeMeasurable
-
Measure elapsed time.
- MECHANISM - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- mechanismName - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
- MEDIAN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- MEGABYTE - Static variable in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
- member - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- member - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- member - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- memberAcquiredBarrier(String, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- memberFinishedBarrier(String, String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- memberName - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- memberRpcs - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- memberRpcs - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- MEMCACHED_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MEMCACHED_DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MEMCACHED_OPTIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MEMCACHED_OPTIMIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MEMCACHED_OPTIMIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MEMCACHED_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MemcachedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
Class to store blocks into memcached.
- MemcachedBlockCache(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- MemcachedBlockCache.HFileBlockTranscoder - Class in org.apache.hadoop.hbase.io.hfile
-
Class to encode and decode an HFileBlock to and from memecached's resulting byte arrays.
- MEMLOAD_BASE - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- memOnly - Variable in class org.apache.hadoop.hbase.regionserver.InternalScan
-
- MEMORY_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- MEMORY_USED - Static variable in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- MemoryBoundedLogMessageBuffer - Class in org.apache.hadoop.hbase.monitoring
-
A size-bounded repository of alerts, which are kept in a linked list.
- MemoryBoundedLogMessageBuffer(long) - Constructor for class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
- MemoryBoundedLogMessageBuffer.LogMessage - Class in org.apache.hadoop.hbase.monitoring
-
- MemoryCompactionPolicy - Enum in org.apache.hadoop.hbase
-
Enum describing all possible memory compaction policies
- MemoryCompactionPolicy() - Constructor for enum org.apache.hadoop.hbase.MemoryCompactionPolicy
-
- memoryFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
In-memory bucket size
- memoryFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
In-memory bucket size
- memoryFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
In-memory bucket size
- memoryLayout - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
- MemoryLayout() - Constructor for class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
-
- memorySize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- memorySize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- MemorySizeUtil - Class in org.apache.hadoop.hbase.io.util
-
Util class to calculate memory size for memstore(on heap, off heap), block cache(L1, L2) of RS.
- MemorySizeUtil() - Constructor for class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- memstore - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- MemStore - Interface in org.apache.hadoop.hbase.regionserver
-
The MemStore holds in-memory modifications to the Store.
- MEMSTORE_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- MEMSTORE_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key to force a flush if there are already enough changes for one region in memstore
- MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which represents the maximum
size of the memstore after which its contents are flushed onto the disk.
- MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- MEMSTORE_FLUSHSIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- MEMSTORE_PERIODIC_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Conf key for the periodic flush interval
- MEMSTORE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MEMSTORE_SIZE_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.MemStoreSizeCostFunction
-
- MEMSTORE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MEMSTORE_SIZE_GAUGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- MEMSTORE_SIZE_GAUGE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
- MEMSTORE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- MEMSTORE_SIZE_LOWER_LIMIT_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- MEMSTORE_SIZE_LOWER_LIMIT_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- MEMSTORE_SIZE_MAX_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- MEMSTORE_SIZE_MIN_RANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- MEMSTORE_SIZE_OLD_KEY - Static variable in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
- MemStoreChunkPool(String, int, ChunkCreator.ChunkType, int, int, float) - Constructor for class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- MemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
-
MemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for
choosing the next action to apply in an (in-memory) memstore compaction.
- MemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- MemStoreCompactionStrategy.Action - Enum in org.apache.hadoop.hbase.regionserver
-
Types of actions to be done on the pipeline upon MemStoreCompaction invocation.
- MemStoreCompactor - Class in org.apache.hadoop.hbase.regionserver
-
The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the
compaction if requested.
- MemStoreCompactor(CompactingMemStore, MemoryCompactionPolicy) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- MemStoreCompactorSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for
compaction operation meaning it is based on SQM
- MemStoreCompactorSegmentsIterator(List<ImmutableSegment>, CellComparator, int, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
- memStoreFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- MemStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Thread that flushes cache on request NOTE: This class extends Thread rather than Chore because
the sleep time can be interrupted when there is something to do, rather than the Chore sleep time
which is invariant.
- MemStoreFlusher(Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
nn
- MemStoreFlusher.FlushHandler - Class in org.apache.hadoop.hbase.regionserver
-
- MemStoreFlusher.FlushQueueEntry - Interface in org.apache.hadoop.hbase.regionserver
-
- MemStoreFlusher.FlushRegionEntry - Class in org.apache.hadoop.hbase.regionserver
-
Datastructure used in the flush queue.
- memstoreFlushSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MemStoreLAB - Interface in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- memStoreLAB - Variable in class org.apache.hadoop.hbase.regionserver.Segment
-
- MemStoreLABImpl - Class in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- MemStoreLABImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- MemStoreLABImpl(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- memstoreLoad - Variable in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- memstoreLoad - Variable in class org.apache.hadoop.hbase.client.RegionLoadStats
-
- memstoreLoadHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
-
- MemStoreMergerSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for
simple merge operation meaning it is NOT based on SQM
- MemStoreMergerSegmentsIterator(List<ImmutableSegment>, CellComparator, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
-
- memstoreOnlyReads - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- memstoreOnlyRowReadsCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- memstoreReplicationEnabled - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- memStoreScannersAfterFlush - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- MemStoreSegmentsIterator - Class in org.apache.hadoop.hbase.regionserver
-
The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments For
another iteration new instance of MemStoreSegmentsIterator needs to be created The iterator is
not thread-safe and must have only one instance per MemStore in each period of time
- MemStoreSegmentsIterator(int) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
-
- memStoreSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- memStoreSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- MemStoreSize - Class in org.apache.hadoop.hbase.regionserver
-
Data structure of three longs.
- MemStoreSize() - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
Package private constructor.
- MemStoreSize(long, long, long, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
Package private constructor.
- MemStoreSize(MemStoreSize) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSize
-
Package private constructor.
- memStoreSize - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- memstoreSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- MemStoreSizeCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Compute the cost of total memstore size.
- MemStoreSizeCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.MemStoreSizeCostFunction
-
- memStoreSizeGauge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- memStoreSizeMB - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- memstoreSizeMB - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- memstoreSizeMB - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- memStoreSizing - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MemStoreSizing - Interface in org.apache.hadoop.hbase.regionserver
-
Accounting of current heap and data sizes.
- memStoreSizing - Variable in class org.apache.hadoop.hbase.regionserver.Segment
-
- MemStoreSnapshot - Class in org.apache.hadoop.hbase.regionserver
-
MemStoreSnapshot
is a Context Object to hold details of the snapshot taken on a MemStore.
- MemStoreSnapshot(long, ImmutableSegment) - Constructor for class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- memstoreTS - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- memstoreTS - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- memType - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- merge(BatchErrors) - Method in class org.apache.hadoop.hbase.client.BatchErrors
-
- merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Merge two configurations.
- merge(BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- merge(WALProcedureMap) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
Merges the provided settings with this
and returns a new settings object to the caller
if the merged settings differ from the original.
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory.QuotaGlobalsSettingsBypass
-
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- merge(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- MERGE_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes if the table is
merge enabled.
- MERGE_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- MERGE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- MERGE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- MERGE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- MERGE_MIN_REGION_AGE_DAYS_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- MERGE_MIN_REGION_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- MERGE_MIN_REGION_SIZE_MB_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- MERGE_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MERGE_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- MERGE_QUALIFIER_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MERGE_QUALIFIER_PREFIX_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Merge qualifier prefix.
- MERGEA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- mergeAssignmentMaps(Map<ServerName, List<RegionInfo>>, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- MERGEB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- mergeChildNodes(NonLeafExpressionNode, Operator, ExpressionNode, NonLeafExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionExpander
-
- mergeConfigurations(Configuration, TableDescriptor, ColumnFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- mergedChild - Variable in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- mergedChild - Variable in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- mergedRegion - Variable in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
The resulting merged region.
- mergedRegions - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- mergeEnabled - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- mergeFamilyMaps(Map<byte[], List<Cell>>, Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- mergeFilterResponse(Cell, ScanQueryMatcher.MatchCode, Filter.ReturnCode) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
Call this when scan has filter.
- mergeFromMethod - Variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- mergeLocations(RegionLocations) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Merges this RegionLocations list with the given list assuming same range, and keeping the most
up to date version of the HRegionLocation entries from either list according to seqNum.
- mergeMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- mergeMinRegionAge - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- mergeMinRegionCount - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- mergeMinRegionSizeMb - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- mergeNodes(BitSetNode, BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Merges leftNode
& rightNode
and updates the map.
- MergeNormalizationPlan - Class in org.apache.hadoop.hbase.master.normalizer
-
Normalization plan to merge adjacent regions.
- MergeNormalizationPlan(List<NormalizationTarget>) - Constructor for class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan
-
- MergeNormalizationPlan.Builder - Class in org.apache.hadoop.hbase.master.normalizer
-
- mergeOverlaps(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo.HDFSIntegrityFixer
-
- mergePlanCount - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- mergeProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- mergeRegionDirs(Path, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Merge hdfs data by moving from contained HbckRegionInfo into targetRegionDir.
- MergeRegionException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when something is wrong in trying to merge two regions.
- MergeRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
default constructor
- MergeRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
Constructor
- MergeRegionException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
- mergeRegionInfo - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- mergeRegions(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
- mergeRegions(List<byte[]>, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Merge multiple regions (>=2).
- mergeRegions(List<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- mergeRegions(List<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- mergeRegions(RegionInfo, RegionInfo[], ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- mergeRegions(RegionInfo[], boolean, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- mergeRegions(RegionInfo[], boolean, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Merge regions in a table.
- mergeRegions(Connection, RegionInfo, Map<RegionInfo, Long>, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Merge regions into one in an atomic operation.
- mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- mergeRegionsAsync(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- mergeRegionsAsync(byte[][], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Merge multiple regions (>=2).
- mergeRegionsAsync(byte[][], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Merge two regions.
- mergeRegionsAsync(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- mergeRegionsAsync(byte[][], boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- mergeRegionsSync(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Merge two regions.
- mergeResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- mergeReturnCode(Filter.ReturnCode, Filter.ReturnCode) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
FilterList with MUST_PASS_ALL choose the maximal forward step among sub-filters in filter list.
- mergeReturnCode(Filter.ReturnCode, Filter.ReturnCode) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
FilterList with MUST_PASS_ONE choose the minimal forward step among sub-filter in filter list.
- mergeStateTracker - Variable in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- mergeStoreFile(RegionInfo, String, HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Write out a merge reference under the given merges directory.
- mergeStoreFiles(MasterProcedureEnv, HRegionFileSystem, HRegionFileSystem, RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the merge switch on or off.
- mergeSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Merge switch on or off.
- mergeSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- mergeSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- mergeSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- mergeSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- mergeTableCFs(Map<TableName, List<String>>, Map<TableName, List<String>>) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- MergeTableRegionProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.MergeTableRegionProcedureBiConsumer
-
- mergeTableRegions(RpcController, MasterProtos.MergeTableRegionsRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- mergeTableRegions(RpcController, MasterProtos.MergeTableRegionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- MergeTableRegionsFuture(HBaseAdmin, TableName, MasterProtos.MergeTableRegionsResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.MergeTableRegionsFuture
-
- MergeTableRegionsFuture(HBaseAdmin, TableName, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.MergeTableRegionsFuture
-
- MergeTableRegionsProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
The procedure to Merge regions in a table.
- MergeTableRegionsProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- MergeTableRegionsProcedure(MasterProcedureEnv, RegionInfo[], boolean) - Constructor for class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- mergeZnode - Variable in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- message - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- message - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
-
- message - Variable in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer.LogMessage
-
the error text, encoded in bytes to save memory
- message - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- MESSAGE_PREFIX - Static variable in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- MESSAGE_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- MessageCodec - Class in org.apache.hadoop.hbase.codec
-
Codec that just writes out Cell as a protobuf Cell Message.
- MessageCodec() - Constructor for class org.apache.hadoop.hbase.codec.MessageCodec
-
- MessageCodec.MessageDecoder - Class in org.apache.hadoop.hbase.codec
-
- MessageCodec.MessageEncoder - Class in org.apache.hadoop.hbase.codec
-
- MessageDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.MessageCodec.MessageDecoder
-
- MessageEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.MessageCodec.MessageEncoder
-
- MessageModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The presentation logic for the message mode.
- MessageModeScreenPresenter(MessageModeScreenView, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
-
- messageModeScreenPresenter - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
-
- messageModeScreenView - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
-
- MessageModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
The message mode in the top screen.
- MessageModeScreenView(Screen, Terminal, int, String, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
-
- messagePeriod - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- messages - Variable in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
- meta - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- meta - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- META_CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
-
- META_CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
-
- META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- META_COMPARATOR - Static variable in class org.apache.hadoop.hbase.MetaCellComparator
-
- META_FAMILY_BYTES - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- META_FAMILY_BYTES - Static variable in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- META_FILTER - Static variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
Filter *in* WAL files that are for the hbase:meta Region.
- META_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- META_QUALIFIER_BYTES - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- META_QUALIFIER_BYTES - Static variable in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- META_QUEUE_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- META_REGION_SET - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
The delimiter for meta columns for replicaIds > 0
- META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
The delimiter for meta columns for replicaIds > 0
- META_REPLICA_ID_DELIMITER - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
-
The delimiter for meta columns for replicaIds > 0
- META_REPLICAS_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
- META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- META_SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- META_SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- META_SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- META_SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
The hbase:meta table's name.
- META_TRANSITION_QOS - Static variable in class org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
-
- META_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
The current version of the meta table.
- META_VERSION_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The meta table version column qualifier.
- META_WAL_GROUP_NAME - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- META_WAL_PROVIDER - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- META_WAL_PROVIDER_ID - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
The hbase:meta region's WAL filename extension
- META_ZNODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- META_ZNODE_PREFIX_CONF_KEY - Static variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- metaAssignEvent - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- metaBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Meta block index reader -- always single level
- metaBlockIndexWriter - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
- MetaBrowser - Class in org.apache.hadoop.hbase.master.http
-
Support class for the "Meta Entries" section in resources/hbase-webapps/master/table.jsp
.
- MetaBrowser(AsyncConnection, HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- MetaBrowser.Results - Class in org.apache.hadoop.hbase.master.http
-
Encapsulates the results produced by this
MetaBrowser
instance.
- metaBuff - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.WriterThread
-
- metaCache - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- MetaCache - Class in org.apache.hadoop.hbase.client
-
A cache implementation for region locations from meta.
- MetaCache(MetricsConnection) - Constructor for class org.apache.hadoop.hbase.client.MetaCache
-
- metaCacheHits - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- metaCacheMisses - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- metaCacheNumClearRegion - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- metaCacheNumClearServer - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- MetaCellComparator - Class in org.apache.hadoop.hbase
-
- MetaCellComparator() - Constructor for class org.apache.hadoop.hbase.MetaCellComparator
-
- MetaCellComparator.Compare<L,R> - Interface in org.apache.hadoop.hbase
-
- MetaCellComparator.SearchDelimiter<T> - Interface in org.apache.hadoop.hbase
-
- MetaCellComparator.SearchDelimiterInReverse<T> - Interface in org.apache.hadoop.hbase
-
- MetaComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Deprecated.
- METADATA - Static variable in class org.apache.hadoop.hbase.HConstants
-
- metaData - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Writable
s representing meta block data.
- metadataMap - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Map of the metadata entries in the corresponding HFile.
- metaEntry - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- MetaEntry(RegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- MetaEntry(RegionInfo, ServerName, long, RegionInfo, RegionInfo) - Constructor for class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- METAFAMILY - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- metaFirstKey - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- MetaFixer - Class in org.apache.hadoop.hbase.master.janitor
-
Server-side fixing of bad or inconsistent state in hbase:meta.
- MetaFixer(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.janitor.MetaFixer
-
- MetaFixer.Either<L,R> - Class in org.apache.hadoop.hbase.master.janitor
-
A union over L
and R
.
- metaHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- metaIndexCount - Variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
The number of entries in the meta index
- metaIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- metaLastKey - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- metaLoadEvent - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- metaLocationSyncer - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MetaLocationSyncer - Class in org.apache.hadoop.hbase.master.zksyncer
-
Tracks the meta region locations on server ZK cluster and synchronize them to client ZK cluster
if changed
- MetaLocationSyncer(ZKWatcher, ZKWatcher, Server) - Constructor for class org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer
-
- metaLock - Variable in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- METALOG - Static variable in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- METALOG - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
-
- metaLogSplit(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Called after we've split the meta logs on a crashed Server.
- metaLogSplitting(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Call this when we start meta log splitting a crashed Server.
- metaLookupPool - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- metaMap - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- metaMissCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- MetaMutationAnnotation - Annotation Type in org.apache.hadoop.hbase
-
The field or the parameter to which this annotation can be applied only when it holds mutations
for hbase:meta table.
- metaNames - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
Meta block names.
- metaOperationTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- metaOperationTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- MetaOperationType() - Constructor for enum org.apache.hadoop.hbase.master.procedure.MetaProcedureInterface.MetaOperationType
-
Deprecated.
- METAPRIORITY_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- METAPRIORITY_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- MetaProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
-
- MetaProcedureInterface.MetaOperationType - Enum in org.apache.hadoop.hbase.master.procedure
-
Deprecated.
- metaProvider - Variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- MetaQueue - Class in org.apache.hadoop.hbase.master.procedure
-
- MetaQueue(LockStatus) - Constructor for class org.apache.hadoop.hbase.master.procedure.MetaQueue
-
Deprecated.
- metaReadRpcTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- metaReadRpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- metaRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if meta region exists
- MetaRegionLocationCache - Class in org.apache.hadoop.hbase
-
A cache of meta region location metadata.
- MetaRegionLocationCache(ZKWatcher) - Constructor for class org.apache.hadoop.hbase.MetaRegionLocationCache
-
- metaRegionLocationCache - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cache for the meta region replica's locations.
- MetaRegionLocationCache.ZNodeOpType - Enum in org.apache.hadoop.hbase
-
- metaRegionLocations - Variable in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- metaRegionLocator - Variable in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- metaRegionLock - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- metaRelocateFuture - Variable in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- metaReplicaCallTimeoutMicroSecondScan - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- metaReplicaCallTimeoutScanInMicroSecond - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- metaReplicaCount - Variable in class org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer
-
- metaReplicaMode - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- metaReplicaMode - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- metaReplicaSelector - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- metaReplicaSelector - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- METAROW - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- metaRunQueue - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- MetaRWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that uses different queues for reads and writes for meta.
- MetaRWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
-
- metaScannerCaching - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- metaScanTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- metaScanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- metaSplitSizeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- metaSplitTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- metaStateDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.MirroringTableStateManager
-
Deprecated.
- metaStateDeleted(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- metaStateUpdated(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.master.MirroringTableStateManager
-
Deprecated.
- metaStateUpdated(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- metaTable - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- MetaTableAccessor - Class in org.apache.hadoop.hbase
-
Read/write operations on hbase:meta
region as well as assignment information stored
to hbase:meta
.
- MetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor
-
- MetaTableAccessor.CloseableVisitor - Interface in org.apache.hadoop.hbase
-
Implementations 'visit' a catalog table row but with close() at the end.
- MetaTableAccessor.CollectAllVisitor - Class in org.apache.hadoop.hbase
-
Collects all returned.
- MetaTableAccessor.CollectingVisitor<T> - Class in org.apache.hadoop.hbase
-
- MetaTableAccessor.DefaultVisitorBase - Class in org.apache.hadoop.hbase
-
A Visitor that skips offline regions and split parents
- MetaTableAccessor.QueryType - Enum in org.apache.hadoop.hbase
-
- MetaTableAccessor.ReplicationBarrierResult - Class in org.apache.hadoop.hbase
-
- MetaTableAccessor.TableVisitorBase - Class in org.apache.hadoop.hbase
-
A Visitor for a table.
- MetaTableAccessor.Visitor - Interface in org.apache.hadoop.hbase
-
Implementations 'visit' a catalog table row.
- metaTableConsistencyCheck(Result) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
Check row.
- MetaTableLocator - Class in org.apache.hadoop.hbase.zookeeper
-
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which
keeps hbase:meta region server location.
- MetaTableLocator() - Constructor for class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- MetaTableMetrics - Class in org.apache.hadoop.hbase.coprocessor
-
A coprocessor that collects metrics from meta table.
- MetaTableMetrics() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- MetaTableMetrics.ExampleRegionObserverMeta - Class in org.apache.hadoop.hbase.coprocessor
-
- MetaTableMetrics.MetaTableOps - Enum in org.apache.hadoop.hbase.coprocessor
-
- MetaTableOps() - Constructor for enum org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.MetaTableOps
-
- MetaTableScanResultConsumer(int, MetaTableAccessor.Visitor, CompletableFuture<Void>) - Constructor for class org.apache.hadoop.hbase.AsyncMetaTableAccessor.MetaTableScanResultConsumer
-
- metaTransitionExecutor - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
This executor is only for meta transition
- MetaWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter.MetaWriter
-
- metaZNodePrefix - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
The prefix of meta znode.
- meter - Variable in class org.apache.hadoop.hbase.metrics.impl.DropwizardMeter
-
- meter(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- meter - Variable in class org.apache.hadoop.hbase.metrics.impl.TimerImpl
-
- Meter - Interface in org.apache.hadoop.hbase.metrics
-
A metric which measure the rate at which some operation is invoked.
- meter(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Get or construct a
Meter
used to measure durations and report distributions (a
combination of a
Timer
and a
Histogram
.
- metersByTable - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
-
- method - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- METHOD - Static variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslAuthenticationProvider
-
- method - Variable in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
- methodMap - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- methodName - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- methodName - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- methodName - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- methods - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
-
- Methods - Class in org.apache.hadoop.hbase.util
-
- Methods() - Constructor for class org.apache.hadoop.hbase.util.Methods
-
- METHODS_TO_IGNORE_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- methodsToIgnore - Variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- Metric - Interface in org.apache.hadoop.hbase.metrics
-
Parent interface for all metrics.
- METRIC_USER_ENABLED_CONF - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
-
- metricCat - Variable in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- MetricHistogram - Interface in org.apache.hadoop.metrics2
-
Metrics Histogram interface.
- MetricQuantile - Class in org.apache.hadoop.metrics2.util
-
- MetricQuantile(double, double) - Constructor for class org.apache.hadoop.metrics2.util.MetricQuantile
-
- MetricRegistries - Class in org.apache.hadoop.hbase.metrics
-
MetricRegistries is collection of MetricRegistry's.
- MetricRegistries() - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistries
-
- MetricRegistries.LazyHolder - Class in org.apache.hadoop.hbase.metrics
-
- MetricRegistriesImpl - Class in org.apache.hadoop.hbase.metrics.impl
-
Implementation of MetricRegistries that does ref-counting.
- MetricRegistriesImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- MetricRegistriesImpl(MetricRegistryFactory) - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- MetricRegistriesLoader - Class in org.apache.hadoop.hbase.metrics
-
- MetricRegistriesLoader() - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
-
- metricRegistry - Variable in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- MetricRegistry - Interface in org.apache.hadoop.hbase.metrics
-
General purpose factory for creating various metrics.
- metricRegistry - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- metricRegistry - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
-
- metricRegistry - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- metricRegistry - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- metricRegistry - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost.WALEnvironment
-
- MetricRegistryFactory - Interface in org.apache.hadoop.hbase.metrics
-
A Factory for creating MetricRegistries.
- MetricRegistryFactoryImpl - Class in org.apache.hadoop.hbase.metrics.impl
-
- MetricRegistryFactoryImpl() - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistryFactoryImpl
-
- MetricRegistryImpl - Class in org.apache.hadoop.hbase.metrics.impl
-
- MetricRegistryImpl(MetricRegistryInfo) - Constructor for class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- MetricRegistryInfo - Class in org.apache.hadoop.hbase.metrics
-
HBase Metrics are grouped in different MetricRegistry'ies.
- MetricRegistryInfo(String, String, String, String, boolean) - Constructor for class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
- metrics - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- metrics(ScanMetrics) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- metrics - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- metrics - Variable in class org.apache.hadoop.hbase.client.MetaCache
-
- metrics - Variable in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- metrics - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- metrics - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- metrics - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Static instance for the metrics so that HFileReaders access the same instance
- metrics - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- metrics - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- metrics - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServerResponseEncoder
-
- metrics - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- metrics - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- metrics - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- metrics - Variable in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- metrics - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- metrics - Variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- metrics - Variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- metrics - Variable in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- metrics - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- metrics - Variable in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Tracks the relevant server side metrics during scans.
- metrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- metrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- metrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- metrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- metrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- metrics - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- metrics - Variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- metrics - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- metrics - Variable in class org.apache.hadoop.hbase.thrift.CallQueue
-
- metrics - Variable in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
-
- metrics - Variable in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- metrics - Variable in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
-
- metrics - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- metrics() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The context metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
-
The name of the metrics context that metrics will be under.
- METRICS_CONTEXT - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics context that metrics will be under.
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
Description
- METRICS_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Description
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
-
A description.
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
- METRICS_DESCRIPTION - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Description
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics context that metrics will be under in jmx
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
-
The name of the metrics context that metrics will be under.
- METRICS_JMX_CONTEXT - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics context that metrics will be under in jmx.
- METRICS_JMX_CONTEXT_SUFFIX - Static variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
The Suffix of the JMX Context that a MetricsHBaseServerSource will register under.
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.io.MetricsIOSource
-
The name of the metrics
- METRICS_NAME - Static variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterProcSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSource
-
The name of the metrics
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
- METRICS_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
The name of the metrics
- METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Region in Transition metrics threshold time
- METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Region in Transition metrics threshold time
- METRICS_SCOPE_KEY - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- metricsAdapter - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
The adapter from hbase-metrics module to metrics2.
- metricsAdapter - Variable in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
- MetricSampleQuantiles - Class in org.apache.hadoop.metrics2.util
-
Implementation of the Cormode, Korn, Muthukrishnan, and Srivastava algorithm for streaming
calculation of targeted high-percentile epsilon-approximate quantiles.
- MetricSampleQuantiles(MetricQuantile[]) - Constructor for class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
- MetricSampleQuantiles.SampleItem - Class in org.apache.hadoop.metrics2.util
-
Describes a measured value passed to the estimator, tracking additional metadata required by
the CKMS algorithm.
- MetricsAssignmentManager - Class in org.apache.hadoop.hbase.master
-
- MetricsAssignmentManager() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- MetricsAssignmentManagerSource - Interface in org.apache.hadoop.hbase.master
-
- MetricsAssignmentManagerSourceImpl - Class in org.apache.hadoop.hbase.master
-
- MetricsAssignmentManagerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- MetricsAssignmentManagerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- metricsBalancer - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- MetricsBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
Faced for exposing metrics about the balancer.
- MetricsBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- MetricsBalancerSource - Interface in org.apache.hadoop.hbase.master.balancer
-
- MetricsBalancerSourceImpl - Class in org.apache.hadoop.hbase.master.balancer
-
- MetricsBalancerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- MetricsBalancerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- MetricsConnection - Class in org.apache.hadoop.hbase.client
-
This class is for maintaining the various connection statistics and publishing them through the
metrics interfaces.
- MetricsConnection(String, Supplier<ThreadPoolExecutor>, Supplier<ThreadPoolExecutor>) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection
-
- MetricsConnection.CallStats - Class in org.apache.hadoop.hbase.client
-
A container class for collecting details about the RPC call as it percolates.
- MetricsConnection.CallTracker - Class in org.apache.hadoop.hbase.client
-
- MetricsConnection.NewMetric<T> - Interface in org.apache.hadoop.hbase.client
-
A lambda for dispatching to the appropriate metric factory method
- MetricsConnection.RegionStats - Class in org.apache.hadoop.hbase.client
-
- MetricsConnection.RunnerStats - Class in org.apache.hadoop.hbase.client
-
- metricsContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- metricsContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
- MetricsCoprocessor - Class in org.apache.hadoop.hbase.coprocessor
-
Utility class for tracking metrics for various types of coprocessors.
- MetricsCoprocessor() - Constructor for class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- metricsDescription - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
- MetricSet - Interface in org.apache.hadoop.hbase.metrics
-
A set of named metrics.
- MetricsExecutor - Interface in org.apache.hadoop.metrics2
-
ScheduledExecutorService for metrics.
- MetricsExecutorImpl - Class in org.apache.hadoop.metrics2.lib
-
Class to handle the ScheduledExecutorService
ScheduledExecutorService
used by
MetricsRegionAggregateSourceImpl, and JmxCacheBuster
- MetricsExecutorImpl() - Constructor for class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
-
- MetricsExecutorImpl.ExecutorSingleton - Enum in org.apache.hadoop.metrics2.lib
-
- MetricsExecutorImpl.ThreadPoolExecutorThreadFactory - Class in org.apache.hadoop.metrics2.lib
-
- MetricsHBaseServer - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServer(String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- MetricsHBaseServerSource - Interface in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerSourceFactory - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerSourceFactory() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
- MetricsHBaseServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
-
- MetricsHBaseServerSourceFactoryImpl.SourceStorage - Enum in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerSourceImpl - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerSourceImpl(String, String, String, String, MetricsHBaseServerWrapper) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- MetricsHBaseServerWrapper - Interface in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerWrapperImpl - Class in org.apache.hadoop.hbase.ipc
-
- MetricsHBaseServerWrapperImpl(RpcServer) - Constructor for class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- metricsHeapMemoryManager - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- MetricsHeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
-
This class is for maintaining the various regionserver's heap memory manager statistics and
publishing them through the metrics interfaces.
- MetricsHeapMemoryManager() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
- MetricsHeapMemoryManager(MetricsHeapMemoryManagerSource) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
- MetricsHeapMemoryManagerSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from
HeapMemoryManager in RegionServer into the hadoop metrics system.
- MetricsHeapMemoryManagerSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
Hadoop2 implementation of MetricsHeapMemoryManagerSource.
- MetricsHeapMemoryManagerSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- MetricsHeapMemoryManagerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- metricsInfo - Variable in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- MetricsInfoImpl - Class in org.apache.hadoop.hbase.metrics
-
Making implementing metric info a little easier
- MetricsInfoImpl(String, String) - Constructor for class org.apache.hadoop.hbase.metrics.MetricsInfoImpl
-
- MetricsIO - Class in org.apache.hadoop.hbase.io
-
- MetricsIO(MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIO
-
- MetricsIO(MetricsIOSource, MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIO
-
- MetricsIOSource - Interface in org.apache.hadoop.hbase.io
-
- MetricsIOSourceImpl - Class in org.apache.hadoop.hbase.io
-
- MetricsIOSourceImpl(MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
-
- MetricsIOSourceImpl(String, String, String, String, MetricsIOWrapper) - Constructor for class org.apache.hadoop.hbase.io.MetricsIOSourceImpl
-
- MetricsIOWrapper - Interface in org.apache.hadoop.hbase.io
-
- MetricsIOWrapperImpl - Class in org.apache.hadoop.hbase.io
-
- MetricsIOWrapperImpl() - Constructor for class org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
-
- metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- metricsJmxContext - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
- metricsMap - Variable in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- metricsMaster - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MetricsMaster - Class in org.apache.hadoop.hbase.master
-
This class is for maintaining the various master statistics and publishing them through the
metrics interfaces.
- MetricsMaster(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMaster
-
- metricsMasterFilesystem - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- MetricsMasterFileSystem - Class in org.apache.hadoop.hbase.master
-
- MetricsMasterFileSystem() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
- MetricsMasterFileSystemSource - Interface in org.apache.hadoop.hbase.master
-
- MetricsMasterFilesystemSourceImpl - Class in org.apache.hadoop.hbase.master
-
- MetricsMasterFilesystemSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- MetricsMasterFilesystemSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- MetricsMasterProcSource - Interface in org.apache.hadoop.hbase.master
-
Interface that classes that expose metrics about the master will implement.
- MetricsMasterProcSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
- MetricsMasterProcSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper
- MetricsMasterProcSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
-
- MetricsMasterProcSourceImpl - Class in org.apache.hadoop.hbase.master
-
Hadoop2 implementation of MetricsMasterSource.
- MetricsMasterProcSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
-
- MetricsMasterProcSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
-
- MetricsMasterQuotaSource - Interface in org.apache.hadoop.hbase.master
-
A collection of exposed metrics for space quotas from the HBase Master.
- MetricsMasterQuotaSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterQuotaSource when given a MetricsMasterWrapper.
- MetricsMasterQuotaSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.
- MetricsMasterQuotaSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
-
- MetricsMasterQuotaSourceImpl - Class in org.apache.hadoop.hbase.master
-
- MetricsMasterQuotaSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- MetricsMasterQuotaSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- MetricsMasterSource - Interface in org.apache.hadoop.hbase.master
-
Interface that classes that expose metrics about the master will implement.
- MetricsMasterSourceFactory - Interface in org.apache.hadoop.hbase.master
-
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
- MetricsMasterSourceFactoryImpl - Class in org.apache.hadoop.hbase.master
-
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
- MetricsMasterSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
-
- MetricsMasterSourceFactoryImpl.FactoryStorage - Enum in org.apache.hadoop.hbase.master
-
- MetricsMasterSourceImpl - Class in org.apache.hadoop.hbase.master
-
Hadoop2 implementation of MetricsMasterSource.
- MetricsMasterSourceImpl(MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- MetricsMasterSourceImpl(String, String, String, String, MetricsMasterWrapper) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- MetricsMasterWrapper - Interface in org.apache.hadoop.hbase.master
-
This is the interface that will expose information to hadoop1/hadoop2 implementations of the
MetricsMasterSource.
- MetricsMasterWrapperImpl - Class in org.apache.hadoop.hbase.master
-
Impl for exposing HMaster Information through JMX
- MetricsMasterWrapperImpl(HMaster) - Constructor for class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- metricsName - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- metricsName - Variable in class org.apache.hadoop.hbase.metrics.MetricRegistryInfo
-
- metricsOutput - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- metricsRegion - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MetricsRegion - Class in org.apache.hadoop.hbase.regionserver
-
This is the glue between the HRegion and whatever hadoop shim layer is loaded
(hbase-hadoop1-compat or hbase-hadoop2-compat).
- MetricsRegion(MetricsRegionWrapper, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- MetricsRegionAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple
regions into the hadoop metrics system.
- MetricsRegionAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- MetricsRegionAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- metricsRegionServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MetricsRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
Maintains regionserver statistics and publishes them through the metrics interfaces.
- MetricsRegionServer(MetricsRegionServerWrapper, Configuration, MetricsTable) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- MetricsRegionServer(MetricsRegionServerWrapper, MetricsRegionServerSource, RegionServerTableMetrics, MetricsTable, MetricsUserAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- metricsRegionServerImpl - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MetricsRegionServerQuotaSource - Interface in org.apache.hadoop.hbase.regionserver
-
A collection of exposed metrics for space quotas from an HBase RegionServer.
- MetricsRegionServerQuotaSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionServerQuotaSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- MetricsRegionServerQuotaSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- MetricsRegionServerSource - Interface in org.apache.hadoop.hbase.regionserver
-
Interface for classes that expose metrics about the regionserver.
- MetricsRegionServerSourceFactory - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of a factory to create Metrics Sources used inside of regionservers.
- MetricsRegionServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.regionserver
-
Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
- MetricsRegionServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- MetricsRegionServerSourceFactoryImpl.FactoryStorage - Enum in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionServerSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
Hadoop2 implementation of MetricsRegionServerSource.
- MetricsRegionServerSourceImpl(MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- MetricsRegionServerSourceImpl(String, String, String, String, MetricsRegionServerWrapper) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- MetricsRegionServerWrapper - Interface in org.apache.hadoop.hbase.regionserver
-
This is the interface that will expose RegionServer information to hadoop1/hadoop2
implementations of the MetricsRegionServerSource.
- MetricsRegionServerWrapperImpl - Class in org.apache.hadoop.hbase.regionserver
-
Impl for exposing HRegionServer Information through Hadoop's metrics 2 system.
- MetricsRegionServerWrapperImpl(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- MetricsRegionServerWrapperImpl.RegionServerMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
-
This is the runnable that will be executed on the executor every PERIOD number of seconds It
will take metrics/numbers from all of the regions and use them to compute point in time
metrics.
- MetricsRegionSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented to allow single regions to push metrics into
MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
- MetricsRegionSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionSourceImpl(MetricsRegionWrapper, MetricsRegionAggregateSourceImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- metricsRegionWrapper - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MetricsRegionWrapper - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of class that will wrap an HRegion and export numbers so they can be used in
MetricsRegionSource
- MetricsRegionWrapperImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsRegionWrapperImpl(HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
-
- metricsRegistry - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- metricsRegistry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- MetricsReplicationGlobalSourceSource - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationGlobalSourceSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationGlobalSourceSourceImpl(MetricsReplicationSourceImpl) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- MetricsReplicationSinkSource - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSinkSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSinkSourceImpl(MetricsReplicationSourceImpl) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- MetricsReplicationSource - Interface in org.apache.hadoop.hbase.replication.regionserver
-
Provides access to gauges and counters.
- MetricsReplicationSourceFactory - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSourceFactoryImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- MetricsReplicationSourceFactoryImpl.SourceHolder - Enum in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
Hadoop2 implementation of MetricsReplicationSource.
- MetricsReplicationSourceImpl() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceImpl
-
- MetricsReplicationSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceImpl
-
- MetricsReplicationSourceSource - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSourceSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationSourceSourceImpl(MetricsReplicationSourceImpl, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- MetricsReplicationTableSource - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- MetricsReplicationTableSourceImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
This is the metric source for table level replication metrics.
- MetricsReplicationTableSourceImpl(MetricsReplicationSourceImpl, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- MetricsREST - Class in org.apache.hadoop.hbase.rest
-
- MetricsREST() - Constructor for class org.apache.hadoop.hbase.rest.MetricsREST
-
- MetricsRESTSource - Interface in org.apache.hadoop.hbase.rest
-
Interface of the Metrics Source that will export data to Hadoop's Metrics2 system.
- MetricsRESTSourceImpl - Class in org.apache.hadoop.hbase.rest
-
Hadoop Two implementation of a metrics2 source that will export metrics from the Rest server to
the hadoop metrics2 subsystem.
- MetricsRESTSourceImpl() - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- MetricsRESTSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- MetricsSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics for a sink and publishing them
through the metrics interfaces.
- MetricsSink() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- metricsSize - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- MetricsSnapshot - Class in org.apache.hadoop.hbase.master
-
- MetricsSnapshot() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshot
-
- metricsSnapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- MetricsSnapshotSource - Interface in org.apache.hadoop.hbase.master
-
- MetricsSnapshotSourceImpl - Class in org.apache.hadoop.hbase.master
-
- MetricsSnapshotSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- MetricsSnapshotSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- MetricsSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
- MetricsSource(String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Constructor used to register the metrics
- MetricsSource(String, MetricsReplicationSourceSource, MetricsReplicationGlobalSourceSource, Map<String, MetricsReplicationTableSource>) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Constructor for injecting custom (or test) MetricsReplicationSourceSources
- metricsSource - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- MetricsSourceAdapter(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter.MetricsSourceAdapter
-
- MetricsStochasticBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
This metrics balancer uses extended source for stochastic load balancer to report its related
metrics to JMX.
- MetricsStochasticBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
-
- MetricsStochasticBalancerSource - Interface in org.apache.hadoop.hbase.master.balancer
-
This interface extends the basic metrics balancer source to add a function to report metrics that
related to stochastic load balancer.
- MetricsStochasticBalancerSourceImpl - Class in org.apache.hadoop.hbase.master.balancer
-
- MetricsStochasticBalancerSourceImpl() - Constructor for class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- metricsTable - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- MetricsTable - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTable(MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTable
-
- MetricsTableAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple
regions of a table into the hadoop metrics system.
- MetricsTableAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
-
- MetricsTableAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
-
- MetricsTableLatencies - Interface in org.apache.hadoop.hbase.regionserver
-
Latency metrics for a specific table in a RegionServer.
- MetricsTableLatenciesImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableLatenciesImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
-
- MetricsTableLatenciesImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl
-
- MetricsTableLatenciesImpl.TableHistograms - Class in org.apache.hadoop.hbase.regionserver
-
- metricsTableMap - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- MetricsTableQueryMeter - Interface in org.apache.hadoop.hbase.regionserver
-
Query Per Second for each table in a RegionServer.
- MetricsTableQueryMeterImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableQueryMeterImpl(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableQueryMeterImpl
-
- MetricsTableQueryMeterImpl.TableMeters - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented to allow region server to push table metrics into
MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
- MetricsTableSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableSourceImpl(String, MetricsTableAggregateSourceImpl, MetricsTableWrapperAggregate) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- MetricsTableValues() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- MetricsTableWrapperAggregate - Interface in org.apache.hadoop.hbase.regionserver
-
Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in
MetricsTableSource
- MetricsTableWrapperAggregateImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableWrapperAggregateImpl(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- MetricsTableWrapperAggregateImpl.MetricsTableValues - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsThriftServerSource - Interface in org.apache.hadoop.hbase.thrift
-
Interface of a class that will export metrics about Thrift to hadoop's metrics2.
- MetricsThriftServerSourceFactory - Interface in org.apache.hadoop.hbase.thrift
-
Factory that will be used to create metrics sources for the two diffent types of thrift servers.
- MetricsThriftServerSourceFactoryImpl - Class in org.apache.hadoop.hbase.thrift
-
Class used to create metrics sources for Thrift and Thrift2 servers.
- MetricsThriftServerSourceFactoryImpl() - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
-
- MetricsThriftServerSourceFactoryImpl.FactoryStorage - Enum in org.apache.hadoop.hbase.thrift
-
A singleton used to make sure that only one thrift metrics source per server type is ever
created.
- MetricsThriftServerSourceImpl - Class in org.apache.hadoop.hbase.thrift
-
- MetricsThriftServerSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- metricsUpdateForGet(List<Cell>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- MetricsUserAggregate - Interface in org.apache.hadoop.hbase.regionserver
-
- MetricsUserAggregateFactory - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsUserAggregateFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
-
- MetricsUserAggregateImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsUserAggregateImpl(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- MetricsUserAggregateSource - Interface in org.apache.hadoop.hbase.regionserver
-
This interface will be implemented by a MetricsSource that will export metrics from multiple
users into the hadoop metrics system.
- MetricsUserAggregateSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsUserAggregateSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- MetricsUserAggregateSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- MetricsUserSource - Interface in org.apache.hadoop.hbase.regionserver
-
- MetricsUserSource.ClientMetrics - Interface in org.apache.hadoop.hbase.regionserver
-
- MetricsUserSourceImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsUserSourceImpl(String, MetricsUserAggregateSourceImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- MetricsUserSourceImpl.ClientMetricsImpl - Class in org.apache.hadoop.hbase.regionserver
-
- MetricsWAL - Class in org.apache.hadoop.hbase.regionserver.wal
-
Class used to push numbers about the WAL into the metrics subsystem.
- MetricsWAL() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- MetricsWAL(MetricsWALSource) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- metricsWALSource - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- MetricsWALSource - Interface in org.apache.hadoop.hbase.regionserver.wal
-
Interface of the source that will export metrics about the region server's WAL.
- MetricsWALSourceImpl - Class in org.apache.hadoop.hbase.regionserver.wal
-
Class that transitions metrics from MetricsWAL into the metrics subsystem.
- MetricsWALSourceImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- MetricsWALSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- MetricsZooKeeperSource - Interface in org.apache.hadoop.hbase.zookeeper
-
Interface of the source that will export metrics about the ZooKeeper.
- MetricsZooKeeperSourceImpl - Class in org.apache.hadoop.hbase.zookeeper
-
Class that transitions metrics from MetricsZooKeeper into the metrics subsystem.
- MetricsZooKeeperSourceImpl() - Constructor for class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- MetricsZooKeeperSourceImpl(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- MID_KEY_METADATA_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
The size of a meta-data record used for finding the mid-key in a multi-level index.
- midKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- midKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- midkey(HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
An approximation to the
HFile
's mid-key.
- midkey(HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- midKey - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
Pre-computed mid-key
- midkey(HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- midKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- midKey - Variable in class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- midKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- midKeyEntry - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- midLeafBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- midLeafBlockOnDiskSize - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- migrate(Configuration, BiConsumer<String, String>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- migrate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- MIGRATE_TABLE_STATE_FROM_ZK_KEY - Static variable in class org.apache.hadoop.hbase.master.TableStateManager
-
Set this key to false in Configuration to disable migrating table state from zookeeper so
hbase:meta table.
- migrateZooKeeper() - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- MIGRATION_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Any artifacts left from migration can be moved here
- MigrationStoreFileTracker - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
A store file tracker used for migrating between store file tracker implementations.
- MigrationStoreFileTracker(Configuration, boolean, StoreContext) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- MILLIS_BETWEEN_NEXTS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_PROTOBUF_IETF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- mimeTypes - Variable in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- min() - Method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Return the minimum value according to this ordering scheme.
- min - Variable in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
-
- MIN_AGE_TO_ARCHIVE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Minimum MOB file age to archive, default (3600000 - 1h)
- MIN_ALLOCATE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- MIN_CLIENT_REQUEST_TIMEOUT - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Minimum allowable timeout (in milliseconds) in rpc request's header.
- MIN_CORE_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.ChoreService
-
The minimum number of threads in the core pool of the underlying ScheduledThreadPoolExecutor
- MIN_COST_NEED_BALANCE_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- MIN_DELAY_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- MIN_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- MIN_FILES_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The minimum number of files to compact within a stripe; same as for regular compaction.
- MIN_FILES_L0_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The minimum number of files to compact when compacting L0; same as minFiles for regular
compaction.
- MIN_FORMAT_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Minimum supported HFile format version
- MIN_FORMAT_VERSION_WITH_TAGS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Minimum HFile format version with support for persisting cell tags
- MIN_INDEX_NUM_ENTRIES_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
Minimum number of entries in a single index block.
- MIN_KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
At least to keep MVCC values in hfiles for 5 days
- MIN_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- MIN_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Minimum minor version supported by this HFile format
- MIN_NUM_HFILE_PATH_LEVELS - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
We assume that HFile path ends with ROOT_DIR/TABLE_NAME/REGION_NAME/CF_NAME/HFILE, so it has at
least this many levels of nesting.
- MIN_PRIORITY - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- MIN_REGION_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- MIN_SECS_BETWEEN_REFRESHES - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- MIN_SECS_BETWEEN_REFRESHES_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- MIN_SERVER_BALANCE - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- MIN_STEP_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- MIN_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MIN_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MIN_V2_MINOR_VERSION_WITH_PB - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
We can read files whose major version is v2 IFF their minor version is at least 3.
- MIN_VERSION_MOVE_SYS_TABLES_CONFIG - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- MIN_VERSIONS_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MIN_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
- MIN_WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
The "core size" of the thread pool.
- MIN_WORKERS_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- MIN_WRITE_BUFFER_PERIODIC_FLUSH_TIMERTICK_MS - Static variable in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Having the timer tick run more often that once every 100ms is needless and will probably cause
too many timer events firing having a negative impact on performance.
- minAge - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- minCellIdx - Variable in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- minClientRequestTimeout - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- minColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- minColumn - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- minColumnInclusive - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- minCompactSize - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- minCostNeedBalance - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- minDelay - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- minDispersionNum - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- minDispersionNumServerSet - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- minDispersionScore - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- minDispersionScoreServerSet - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- minFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Minimum threshold of cache (when evicting, evict until size < min)
- minFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Minimum threshold of cache (when evicting, evict until size < min)
- minFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Minimum threshold of cache (when evicting, evict until size < min)
- minFilesToCompact - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
This one can be update
- MiniBatchOperationInProgress<T> - Class in org.apache.hadoop.hbase.regionserver
-
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
- MiniBatchOperationInProgress(T[], OperationStatus[], WALEdit[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- miniBatchSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- miniClusterRunning - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- minIdleTimeBeforeClose - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- miniHBaseClusterRunning - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- MINIMAL_DELTA_FOR_LOGGING - Static variable in class org.apache.hadoop.hbase.util.Sleeper
-
- minimumScanTimeLimitDelta - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
The minimum allowable delta to use for the scan limit
- minimumStepSize - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- minimumTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- minimumTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- minIndexNumEntries - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The maximum level of multi-level index blocks
- MiniZooKeeperCluster - Class in org.apache.hadoop.hbase.zookeeper
-
TODO: Most of the code in this class is ripped from ZooKeeper tests.
- MiniZooKeeperCluster() - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- MiniZooKeeperCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- minLengthForSpeedCheck - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- minLocalityToForceCompact - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- minLogSeqNum - Variable in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- minModifiedProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- minModifiedProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- MINOR_COMPACTION_DROP_CACHE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- MINOR_VERSION - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
-
- MINOR_VERSION_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
In HFile minor version that does not support checksums
- MINOR_VERSION_WITH_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Minor versions in HFile starting with this number have hbase checksums
- MINOR_VERSION_WITH_FAKED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Minor versions starting with this number have faked index key
- minorCompactionCompression - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- MinorCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for minor compaction.
- MinorCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
-
- minorInProgress - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- minorVersion - Variable in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
The
HFile
format minor version.
- minPacketFlushSpeedKBs - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- minProcId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- minRegionsOnRS - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- minSeqIdToKeep - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
Min SeqId to keep during a major compaction
- minSequenceId - Variable in class org.apache.hadoop.hbase.regionserver.Segment
-
- minSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- minSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- minSizeForReservoirUse - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- minSlowDetectCount - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- minStamp - Variable in class org.apache.hadoop.hbase.io.TimeRange
-
- minStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- minStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- minStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- minTimeBetweenRefreshesMs - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- minTimestamp - Variable in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- minTolerableReplication - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII for Minus Sign
- MINUTE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- minVersions - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- minVersionToMoveSysTables - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
When the operator uses this configuration option, any version between the current cluster
version and the value of "hbase.min.version.move.system.tables" does not trigger any
auto-region movement.
- MIRROR_TABLE_STATE_TO_ZK_KEY - Static variable in class org.apache.hadoop.hbase.master.MirroringTableStateManager
-
Deprecated.
Set this key to true in Configuration to enable mirroring of table state out to zookeeper so
hbase-1.x clients can pick-up table state.
- MirroringTableStateManager - Class in org.apache.hadoop.hbase.master
-
- MirroringTableStateManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.MirroringTableStateManager
-
Deprecated.
- mirrorMetaLocation(RegionInfo, ServerName, RegionState.State) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- mirrorMetaLocations() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- MISC_INVOATION_COUNT - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
- miscCount - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- miss(boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- miss - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- missCachingCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
The number of getBlock requests that were cache misses, but only from requests that were set to
use the block cache.
- missCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
The number of getBlock requests that were cache misses
- missedMobFiles - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- missedStartTime() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Returns true when the time between runs exceeds the acceptable threshold
- missing - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- MISSING_MOB_FILES_CACHE_CAPACITY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- MissingSnapshotViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
-
- MissingSnapshotViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- MIXED_ROW_READS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- MIXED_ROW_READS_ON_STORE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- mixedReads - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- mixedReadsOnStore - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- mixedRowReadsCount - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- mkdir(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- mkdirs(FileSystem, Configuration, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- mob - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- MOB_CACHE_BLOCKS - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_CACHE_EVICT_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_CACHE_EVICT_REMAIN_RATIO - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_CELLS_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for the number of mob cells in metadata
- MOB_CLEANER_BATCH_SIZE_UPPER_BOUND - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_CLEANER_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_COMPACT_PARTITION_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- MOB_COMPACT_PARTITION_POLICY_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_COMPACT_PARTITION_POLICY_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- MOB_COMPACTION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The max number of the mob files that is allowed in a batch of the mob compaction.
- MOB_COMPACTION_CHORE_PERIOD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The period that MobCompactionChore runs.
- MOB_COMPACTION_MAX_FILE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Maximum size of a MOB compaction selection
- MOB_COMPACTION_MERGEABLE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
If the size of a mob file is less than this value, it's regarded as a small file and needs to
be merged in mob compaction.
- MOB_COMPACTION_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_COMPACTION_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobStoreEngine
-
- MOB_DELFILE_MAX_COUNT - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The max number of del files that is allowed in the mob file compaction.
- MOB_DIR_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_FILE_CACHE_ACCESS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_ACCESS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_EVICTED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_EVICTED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_HIT_PERCENT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_HIT_PERCENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_MISS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_MISS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FILE_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_FILE_REFS - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for the list of MOB file references
- MOB_FLUSH_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FLUSH_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FLUSHED_CELLS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FLUSHED_CELLS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FLUSHED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_FLUSHED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_MAJOR_COMPACTION_REGION_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
The max number of a MOB table regions that is allowed in a batch of the mob compaction.
- MOB_REF_TAG - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_REFERENCE_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- MOB_REGION_NAME - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_REGION_NAME_BYTES - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_REGIONS - Static variable in class org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
-
- MOB_SCAN_CELLS_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_SCAN_CELLS_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_SCAN_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_SCAN_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- MOB_SCAN_RAW - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_SCAN_REF_ONLY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_TABLE_LOCK_SUFFIX - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
- MOB_TABLE_NAME_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- MOB_THRESHOLD_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- MOB_THRESHOLD_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- MOB_UNSAFE_DISCARD_MISS_KEY - Static variable in class org.apache.hadoop.hbase.mob.MobConstants
-
Use this configuration option with caution, only during upgrade procedure to handle missing MOB
cells during compaction.
- MobCell - Class in org.apache.hadoop.hbase.mob
-
- MobCell(Cell) - Constructor for class org.apache.hadoop.hbase.mob.MobCell
-
- MobCell(Cell, StoreFileScanner) - Constructor for class org.apache.hadoop.hbase.mob.MobCell
-
- mobCellValueSizeThreshold - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
- mobCompactionLock - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- mobCompactionStates - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MobCompactPartitionPolicy - Enum in org.apache.hadoop.hbase.client
-
Enum describing the mob compact partition policy types.
- MobCompactPartitionPolicy() - Constructor for enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
-
- MobConstants - Class in org.apache.hadoop.hbase.mob
-
The constants used in mob.
- MobConstants() - Constructor for class org.apache.hadoop.hbase.mob.MobConstants
-
- mobDataDir - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- mobFamilyPath - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- MobFile - Class in org.apache.hadoop.hbase.mob
-
The mob file.
- MobFile() - Constructor for class org.apache.hadoop.hbase.mob.MobFile
-
- MobFile(HStoreFile) - Constructor for class org.apache.hadoop.hbase.mob.MobFile
-
- MobFileCache - Class in org.apache.hadoop.hbase.mob
-
The cache for mob files.
- MobFileCache(Configuration) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCache
-
- mobFileCache - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobFileCache - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mobFileCache - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- mobFileCache - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- MobFileCache.EvictionThread - Class in org.apache.hadoop.hbase.mob
-
- mobFileCacheAccessCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFileCacheCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFileCacheEvictedCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFileCacheHitRatio - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFileCacheMissCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFileCleanerChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MobFileCleanerChore - Class in org.apache.hadoop.hbase.mob
-
The class MobFileCleanerChore for running cleaner regularly to remove the expired and obsolete
(files which have no active references to) mob files.
- MobFileCleanerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- MobFileCleanerChore() - Constructor for class org.apache.hadoop.hbase.mob.MobFileCleanerChore
-
- mobFileCompactionChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MobFileCompactionChore - Class in org.apache.hadoop.hbase.mob
-
Periodic MOB compaction chore.
- MobFileCompactionChore(HMaster) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- MobFileCompactionChore(Configuration, int) - Constructor for class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- mobFileExists(FileSystem, TableName, String, String, Set<String>, Set<String>) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
Checks whether the referenced mob file exists.
- mobFileLocations - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- mobFileMaxCacheSize - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- MobFileName - Class in org.apache.hadoop.hbase.mob
-
The mob file name.
- MobFileName(byte[], String, String, String) - Constructor for class org.apache.hadoop.hbase.mob.MobFileName
-
n * The start key.
- MobFileName(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.mob.MobFileName
-
n * The md5 hex string of the start key.
- mobFilesChecked - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- mobFlushCount - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobFlushCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFlushedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobFlushedCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobFlushedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobFlushedCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobLengthMap - Static variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- mobPath - Variable in class org.apache.hadoop.hbase.io.HFileLink
-
- MobReferenceOnlyFilter - Class in org.apache.hadoop.hbase.regionserver
-
A filter that returns the cells which have mob reference tags.
- MobReferenceOnlyFilter() - Constructor for class org.apache.hadoop.hbase.regionserver.MobReferenceOnlyFilter
-
- MobRefMapper() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper
-
- MobRefReducer() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- MobRefReporter - Class in org.apache.hadoop.hbase.mob.mapreduce
-
Scans a given table + CF for all mob reference cells to get the list of backing mob files.
- MobRefReporter() - Constructor for class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
- MobRefReporter.MobRefMapper - Class in org.apache.hadoop.hbase.mob.mapreduce
-
- MobRefReporter.MobRefReducer - Class in org.apache.hadoop.hbase.mob.mapreduce
-
- mobRefSet - Static variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- mobRefSet - Static variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
- mobRegion - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- MobRegionDirChecker(Path) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker.MobRegionDirChecker
-
- mobScanCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobScanCellsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobScanCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- mobScanCellsSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- mobSizeThreshold - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- mobStore - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- mobStore - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
- mobStore - Variable in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- mobStore - Variable in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- MobStoreEngine - Class in org.apache.hadoop.hbase.mob
-
MobStoreEngine creates the mob specific compactor, and store flusher.
- MobStoreEngine() - Constructor for class org.apache.hadoop.hbase.mob.MobStoreEngine
-
- MobStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the MOB Store.
- MobStoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- MobUtils - Class in org.apache.hadoop.hbase.mob
-
The mob utilities
- MobUtils() - Constructor for class org.apache.hadoop.hbase.mob.MobUtils
-
Private constructor to keep this class from being instantiated.
- MOCKED_LIST - Static variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
A mocked list implementation - discards all updates.
- Mode - Enum in org.apache.hadoop.hbase.hbtop.mode
-
Represents a display mode in the top screen.
- Mode(String, String, ModeStrategy) - Constructor for enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- MODE_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- modeDescriptionMaxLength - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- modeHeaderMaxLength - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- modes - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- ModeScreenPresenter - Class in org.apache.hadoop.hbase.hbtop.screen.mode
-
The presentation logic for the mode screen.
- ModeScreenPresenter(ModeScreenView, Mode, Consumer<Mode>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- modeScreenPresenter - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- modeScreenView - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- ModeScreenView - Class in org.apache.hadoop.hbase.hbtop.screen.mode
-
The screen where we can choose the
Mode
in the top screen.
- ModeScreenView(Screen, Terminal, Mode, Consumer<Mode>, ScreenView) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- modeStrategy - Variable in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
- ModeStrategy - Interface in org.apache.hadoop.hbase.hbtop.mode
-
An interface for strategy logic for
Mode
.
- ModeStrategyUtils - Class in org.apache.hadoop.hbase.hbtop.mode
-
- ModeStrategyUtils() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
-
- modified - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- modifiedTableDescriptor - Variable in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- modifiedTableDescriptor - Variable in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- modifiedTableDescriptor - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- modify(MasterProcedureEnv, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
Sub class should implement this method to modify the table descriptor, such as storing the rs
group information.
- modify(MasterProcedureEnv, TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
-
- ModifyableColumnFamilyDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Construct a column descriptor specifying only the family name The other attributes are
defaulted.
- ModifyableColumnFamilyDescriptor(ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Constructor.
- ModifyableColumnFamilyDescriptor(byte[], Map<Bytes, Bytes>, Map<String, String>) - Constructor for class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- ModifyableTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Construct a table descriptor specifying a TableName object
- ModifyableTableDescriptor(TableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- ModifyableTableDescriptor(TableName, TableDescriptor) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Deprecated.
- ModifyableTableDescriptor(TableName, Collection<ColumnFamilyDescriptor>, Map<Bytes, Bytes>) - Constructor for class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- modifyColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyColumn(RpcController, MasterProtos.ModifyColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the column descriptor of an existing column in an existing table
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing column family on a table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- modifyColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Modifies the existing column family.
- modifyColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- modifyColumnFamily(TTableName, TColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing column family on a table.
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ModifyColumnFamilyFuture(HBaseAdmin, TableName, MasterProtos.ModifyColumnResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyColumnFamilyFuture
-
- ModifyColumnFamilyProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyColumnFamilyProcedureBiConsumer
-
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table's given family.
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Change the store file tracker of the given table's given family.
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- modifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- modifyColumnFamilyStoreFileTrackerAsync(TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table's given family.
- modifyColumnFamilyStoreFileTrackerAsync(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyColumnFamilyStoreFileTrackerAsync(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ModifyColumnFamilyStoreFileTrackerFuture(HBaseAdmin, TableName, MasterProtos.ModifyColumnStoreFileTrackerResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyColumnFamilyStoreFileTrackerFuture
-
- ModifyColumnFamilyStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
- ModifyColumnFamilyStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- ModifyColumnFamilyStoreFileTrackerProcedure(MasterProcedureEnv, TableName, byte[], String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- ModifyColumnFamilyStoreFileTrackerProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyColumnFamilyStoreFileTrackerProcedureBiConsumer
-
- modifyColumnStoreFileTracker(RpcController, MasterProtos.ModifyColumnStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyColumnStoreFileTracker(TableName, byte[], String, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyColumnStoreFileTracker(RpcController, MasterProtos.ModifyColumnStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyColumnStoreFileTracker(TableName, byte[], String, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the store file tracker of an existing column in an existing table
- modifyFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Modifies the existing column family.
- modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing namespace.
- modifyNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing namespace.
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in interface org.apache.hadoop.hbase.master.ClusterSchema
-
Modify an existing Namespace.
- modifyNamespace(NamespaceDescriptor, NonceKey, ProcedurePrepareLatch) - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- modifyNamespace(NamespaceDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Modify an existing Namespace.
- modifyNamespace(RpcController, MasterProtos.ModifyNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- modifyNamespace(TNamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- modifyNamespaceAsync(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing namespace.
- modifyNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyNamespaceAsync(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ModifyNamespaceProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to add a namespace to an existing table.
- ModifyNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- ModifyNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- ModifyNamespaceProcedure(MasterProcedureEnv, NamespaceDescriptor, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- ModifyNamespaceProcedureBiConsumer(String) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyNamespaceProcedureBiConsumer
-
- modifyOrMoveTables(Set<TableName>, RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- ModifyPeerProcedure - Class in org.apache.hadoop.hbase.master.replication
-
The base class for all replication peer related procedure except sync replication state
transition.
- ModifyPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- ModifyPeerProcedure(String) - Constructor for class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- ModifyRegionUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the regions.
- ModifyRegionUtils() - Constructor for class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
- ModifyRegionUtils.RegionEditTask - Interface in org.apache.hadoop.hbase.util
-
- ModifyRegionUtils.RegionFillTask - Interface in org.apache.hadoop.hbase.util
-
- ModifyStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
This procedure is used to change the store file tracker implementation.
- ModifyStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- ModifyStoreFileTrackerProcedure(MasterProcedureEnv, TableName, String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- ModifyStoreFileTrackerProcedure.StoreFileTrackerState - Enum in org.apache.hadoop.hbase.regionserver.storefiletracker
-
- modifyTable(TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Modify an existing table, more IRB friendly version.
- modifyTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- modifyTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyTable(TableName, HMaster.TableDescriptorGetter, long, long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyTable(TableName, TableDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyTable(RpcController, MasterProtos.ModifyTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyTable(TableName, TableDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the descriptor of an existing table
- modifyTable(TableName, TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- modifyTable(TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- modifyTable(TTableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- modifyTableAsync(TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- modifyTableAsync(TableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Modify an existing table, more IRB (ruby) friendly version.
- modifyTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTableAsync(TableName, TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- modifyTableAsync(TableDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ModifyTableDescriptorProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure will only update the table descriptor without reopening all the regions.
- ModifyTableDescriptorProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- ModifyTableDescriptorProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- ModifyTableFuture(HBaseAdmin, TableName, MasterProtos.ModifyTableResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTableFuture
-
- ModifyTableFuture(HBaseAdmin, TableName, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTableFuture
-
- ModifyTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- ModifyTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- ModifyTableProcedure(MasterProcedureEnv, TableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- ModifyTableProcedure(MasterProcedureEnv, TableDescriptor, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- ModifyTableProcedure(MasterProcedureEnv, TableDescriptor, ProcedurePrepareLatch, TableDescriptor, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- ModifyTableProcedureBiConsumer(AsyncAdmin, TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyTableProcedureBiConsumer
-
- ModifyTablerStoreFileTrackerFuture(HBaseAdmin, TableName, MasterProtos.ModifyTableStoreFileTrackerResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTablerStoreFileTrackerFuture
-
- modifyTables(Set<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- modifyTablesAndWaitForCompletion(Set<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table.
- modifyTableStoreFileTracker(TableName, String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Change the store file tracker of the given table.
- modifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- modifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- modifyTableStoreFileTracker(RpcController, MasterProtos.ModifyTableStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- modifyTableStoreFileTracker(TableName, String, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- modifyTableStoreFileTracker(RpcController, MasterProtos.ModifyTableStoreFileTrackerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- modifyTableStoreFileTracker(TableName, String, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Modify the store file tracker of an existing table
- modifyTableStoreFileTrackerAsync(TableName, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Change the store file tracker of the given table.
- modifyTableStoreFileTrackerAsync(TableName, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTableStoreFileTrackerAsync(TableName, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- ModifyTableStoreFileTrackerProcedure - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
- ModifyTableStoreFileTrackerProcedure() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- ModifyTableStoreFileTrackerProcedure(MasterProcedureEnv, TableName, String) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- ModifyTableStoreFileTrackerProcedureBiConsumer(AsyncAdmin, TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ModifyTableStoreFileTrackerProcedureBiConsumer
-
- modTime - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- monitor - Variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- monitor - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- monitor - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
monitor to check for errors
- monitor - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
monitor to check for errors
- monitor - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- monitor - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- monitor - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- Monitor(Connection, String[], boolean, CanaryTool.Sink, ExecutorService, boolean, long) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- Monitor() - Constructor for class org.apache.hadoop.hbase.util.JvmPauseMonitor.Monitor
-
- MONITOR_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- MONITORED_RPC - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Keeps MonitoredRPCHandler per handler thread.
- MonitoredRPCHandler - Interface in org.apache.hadoop.hbase.monitoring
-
A MonitoredTask implementation optimized for use with RPC Handlers handling frequent, short
duration tasks.
- MonitoredRPCHandlerImpl - Class in org.apache.hadoop.hbase.monitoring
-
A MonitoredTask implementation designed for use with RPC Handlers handling frequent, short
duration tasks.
- MonitoredRPCHandlerImpl() - Constructor for class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- MonitoredTask - Interface in org.apache.hadoop.hbase.monitoring
-
- MonitoredTask.State - Enum in org.apache.hadoop.hbase.monitoring
-
- MonitoredTask.StatusJournalEntry - Interface in org.apache.hadoop.hbase.monitoring
-
- MonitoredTaskImpl - Class in org.apache.hadoop.hbase.monitoring
-
- MonitoredTaskImpl(boolean) - Constructor for class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- MonitoredTaskImpl.StatusJournalEntryImpl - Class in org.apache.hadoop.hbase.monitoring
-
- monitorInterval - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- monitorRegionServers(Map<String, List<RegionInfo>>, CanaryTool.RegionServerStdOutSink) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- MonitorRunnable() - Constructor for class org.apache.hadoop.hbase.monitoring.TaskMonitor.MonitorRunnable
-
- monitorStatus - Variable in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- monitorStatus - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- monitorThread - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- monitorThread - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- moreCellsInRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
Based on the nextKv in the heap, and the current row, decide whether or not there are more
cells to be read in the heap.
- MoreResults() - Constructor for enum org.apache.hadoop.hbase.client.ScannerCallable.MoreResults
-
- moreResultsForScan - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- moreResultsForScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Should the client attempt to fetch more results for the whole scan.
- moreResultsForScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- moreResultsInRegion - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- moreResultsInRegion() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Should the client attempt to fetch more results from this region
- moreResultsInRegion() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- moreRows - Variable in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- moreRowsMayExistAfter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- moreRowsMayExistsAfter(int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- moreValues - Variable in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- mostLoadedRSSet - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- mostRecent - Variable in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
- mother - Variable in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- move(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Move the region encodedRegionName
to a random server.
- move(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Move the region rencodedRegionName
to destServerName
.
- move(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region r
to a random server.
- move(byte[], ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Move the region r
to dest
.
- move(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- move(byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- move(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- move(byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- move(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- move(byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- move(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- move(MasterProcedureEnv, RegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- move(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- move(byte[], ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- MOVE_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- MOVE_COST_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- MOVE_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- MOVE_RETRIES_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- MOVE_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- moveAndClose(Path) - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.File
-
Move the file to the given destination n * @return true on success n
- moveAsideBadEditsFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Move aside a bad edits file.
- moveAsync(RegionPlan) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Jumps back the current position of this ByteBuff by specified length.
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Jumps back the current position of this MBB by specified length.
- moveBack(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- moveBufferToStream(OutputStream, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Copy the data to the output stream and update position in buffer.
- moveCost - Variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- 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.
- MoveCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- moveCostOffPeak - Variable in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- moveCursor(int, int) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- movedRegionCacheExpiredTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- movedRegionException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- movedRegionException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- MovedRegionInfo(ServerName, long) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionInfo
-
- movedRegionInfoCache - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Used to cache the moved-out regions
- movedRegions - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
-
- movedRegions - Variable in class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- moveFilesUnderDir(FileSystem, Path, Path, String) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegionUtils
-
- moveForwardMostRecentPosition() - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
Move forward the most recent index.
- moveFromOnlineToDeadServers(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called when server has expired.
- moveHFileToGlobalArchiveDir() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- moveMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- moveMode - Variable in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- moveProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- moveRegion(RegionInfo, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- moveRegion(RpcController, MasterProtos.MoveRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- MoveRegionAction - Class in org.apache.hadoop.hbase.master.balancer
-
- MoveRegionAction(int, int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.MoveRegionAction
-
- MoveRegionProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
- MoveRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- movesCalculated - Variable in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
- movesCalculated - Variable in class org.apache.hadoop.hbase.client.BalanceResponse
-
- moveServerRegionsFromGroup(Set<Address>, Set<TableName>, Set<Address>, String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Move every region from servers which are currently located on these servers, but should not be
located there.
- moveServers(Set<Address>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Move given set of servers to the specified target RegionServer group.
- moveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- moveServers(RpcController, RSGroupAdminProtos.MoveServersRequest, RpcCallback<RSGroupAdminProtos.MoveServersResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- moveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- moveServers(Set<Address>, String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Move servers to a new group.
- moveServers(Set<Address>, String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Move given set of servers and tables to the specified target RegionServer group.
- moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- moveServersAndTables(RpcController, RSGroupAdminProtos.MoveServersAndTablesRequest, RpcCallback<RSGroupAdminProtos.MoveServersAndTablesResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- moveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- moveServersAndTables(Set<Address>, Set<TableName>, String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Move servers and tables to a new group.
- moveServersAndTables(Set<Address>, Set<TableName>, String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- movesExecuted - Variable in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
- movesExecuted - Variable in class org.apache.hadoop.hbase.client.BalanceResponse
-
- moveTableRegionsToGroup(Set<TableName>, RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
Moves regions of tables which are not on target group servers.
- moveTables(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Move given set of tables to the specified target RegionServer group.
- moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- moveTables(RpcController, RSGroupAdminProtos.MoveTablesRequest, RpcCallback<RSGroupAdminProtos.MoveTablesResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- moveTables(Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Set the group membership of a set of tables
- moveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- moveTableToRSGroup(TableDescriptor, RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- moveTableToValidRSGroup(TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- moveToHead(LRUDictionary.BidirectionalLRUMap.Node) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- moveToNext() - Method in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- moveToNextBatch(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
If there is an open hash batch, complete it and sync if there are diffs.
- moveToNextHour(Calendar) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- moveToNextRegion() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
Close the previous scanner and create a new ScannerCallable for the next scanner.
- moveToPrevious() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- moveToPrevious() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- moveWAL(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
Move WAL.
- MoveWithAck - Class in org.apache.hadoop.hbase.util
-
Move Regions and make sure that they are up on the target server.If a region movement fails we
exit as failure
- MoveWithAck(Connection, RegionInfo, ServerName, ServerName, List<RegionInfo>) - Constructor for class org.apache.hadoop.hbase.util.MoveWithAck
-
- MoveWithoutAck - Class in org.apache.hadoop.hbase.util
-
Move Regions without Acknowledging.Usefule in case of RS shutdown as we might want to shut the RS
down anyways and not abort on a stuck region.
- MoveWithoutAck(Admin, RegionInfo, ServerName, ServerName, List<RegionInfo>) - Constructor for class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- MovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
The purpose of introduction of
MovingAverage
mainly is to measure execution time of a
specific method, which can help us to know its performance fluctuation in response to different
machine states or situations, better case, then to act accordingly.
- MovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.MovingAverage
-
- mpmHost - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- MR_NUM_MAPS - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- MRU_LOAD_FACTOR - Static variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- mruCap - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- MSG_TYPE - Static variable in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- MSG_TYPE - Static variable in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
Deprecated.
- MSG_WAIT - Static variable in exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- MSG_WAIT - Static variable in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
Deprecated.
- msgInterval - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- MSLAB_CLASS_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- mslabs - Variable in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- mss - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- mtime - Variable in class org.apache.hadoop.hbase.security.access.AuthManager
-
- multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- multi(RpcController, ClientProtos.MultiRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Execute multiple actions on a table: get, mutate, and/or execCoprocessor
- multi(Iterable<Op>) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Run multiple operations in a transactional manner.
- MULTI_BYTE_BUFFER_HEAP_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- MULTI_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- MULTI_GETS - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MULTI_MUTATIONS - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MULTI_SERVICE_CALLS - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- MULTI_TABLE_HFILEOUTPUTFORMAT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- multiAction - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.SingleServerRequestRunnable
-
- MultiAction - Class in org.apache.hadoop.hbase.client
-
Container for Actions (i.e.
- MultiAction() - Constructor for class org.apache.hadoop.hbase.client.MultiAction
-
- multiAction - Variable in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- MultiActionResultTooLarge - Exception in org.apache.hadoop.hbase
-
Exception thrown when the result needs to be chunked on the server side.
- MultiActionResultTooLarge(String) - Constructor for exception org.apache.hadoop.hbase.MultiActionResultTooLarge
-
- multiActionTooLargeException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- multiActionTooLargeException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- multiAp - Variable in class org.apache.hadoop.hbase.client.HTable
-
The Async process for batch
- MultiByteBuff - Class in org.apache.hadoop.hbase.nio
-
Provides a unified view of all the underlying ByteBuffers and will look as if a bigger sequential
buffer.
- MultiByteBuff(ByteBuffer...) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- MultiByteBuff(ByteBuffAllocator.Recycler, ByteBuffer...) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- MultiByteBuff(RefCnt, ByteBuffer...) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- MultiByteBuff(RefCnt, ByteBuffer[], int[], int, int, int, int) - Constructor for class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- MulticastListener() - Constructor for class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener
-
- MulticastPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- multiFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Multiple access bucket size
- multiFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Multiple access bucket size
- multiFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Multiple access bucket size
- multiGetsCount - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- multiGetsCount - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- MultiHConnection - Class in org.apache.hadoop.hbase.util
-
Provides ability to create multiple Connection instances and allows to process a batch of actions
using CHTable.doBatchWithCallback()
- MultiHConnection(Configuration, int) - Constructor for class org.apache.hadoop.hbase.util.MultiHConnection
-
Create multiple Connection instances and initialize a thread pool executor
- multiMutate(Table, byte[], Mutation...) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- multiMutate(Table, byte[], List<Mutation>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs an atomic multi-mutate operation against the given table.
- multiMutate(List<Mutation>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- multiMutationsCount - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- multiMutationsCount - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- multiOrSequential(ZKWatcher, List<ZKUtil.ZKUtilOp>, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Use ZooKeeper's multi-update functionality.
- multiple(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte array which is multiple given bytes nn * @return byte array
- MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches a particular prefix.
- MultipleColumnPrefixFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- multiplexer - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- multiplier - Variable in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- multiplier - Static variable in class org.apache.hadoop.hbase.util.Random64
-
- multiply(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- multiply(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- multiply(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- multiply(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
nnn
- multiRackCase(ServerName, String) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
Place secondary and tertiary nodes in a multi rack case.
- multiRackCaseWithRestrictions(Map<ServerName, Set<RegionInfo>>, Map<RegionInfo, ServerName[]>, String, ServerName, RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- MultiResponse - Class in org.apache.hadoop.hbase.client
-
A container for Result objects, grouped by regionName.
- MultiResponse() - Constructor for class org.apache.hadoop.hbase.client.MultiResponse
-
- MultiResponse.RegionResult - Class in org.apache.hadoop.hbase.client
-
- MultiRowMutationEndpoint - Class in org.apache.hadoop.hbase.coprocessor
-
- MultiRowMutationEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- MultiRowRangeFilter - Class in org.apache.hadoop.hbase.filter
-
Filter to support scan multiple row key ranges.
- MultiRowRangeFilter(List<MultiRowRangeFilter.RowRange>) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- MultiRowRangeFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
Constructor for creating a MultiRowRangeFilter
from multiple rowkey prefixes.
- MultiRowRangeFilter.BasicRowRange - Class in org.apache.hadoop.hbase.filter
-
- MultiRowRangeFilter.RangeIteration - Class in org.apache.hadoop.hbase.filter
-
Abstraction over the ranges of rows to return from this filter, regardless of forward or
reverse scans being used.
- MultiRowRangeFilter.ReversedRowRange - Class in org.apache.hadoop.hbase.filter
-
Internal RowRange that reverses the sort-order to handle reverse scans.
- MultiRowRangeFilter.RowRange - Class in org.apache.hadoop.hbase.filter
-
- MultiRowResource - Class in org.apache.hadoop.hbase.rest
-
- MultiRowResource(TableResource, String, String) - Constructor for class org.apache.hadoop.hbase.rest.MultiRowResource
-
Constructor nn * @throws java.io.IOException
- MultiServerCallable - Class in org.apache.hadoop.hbase.client
-
Callable that handles the multi
method call going against a single regionserver;
i.e.
- MultiServerCallable(ClusterConnection, TableName, ServerName, MultiAction, RpcController, int, RetryingTimeTracker, int) - Constructor for class org.apache.hadoop.hbase.client.MultiServerCallable
-
- multiServersPerHost - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- multiServiceCalls - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- multiServiceCalls - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- multiSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- multiSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- MultiTableHFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Create 3 level tree directory, first level is using table name as parent directory and then use
family name as child directory, and all related HFiles for one family are under child directory
-tableName1 -columnFamilyName1 -columnFamilyName2 -HFiles -tableName2 -columnFamilyName1 -HFiles
-columnFamilyName2
- MultiTableHFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- MultiTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
- MultiTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
- MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
- MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- MultiTableOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Hadoop output format that writes to one or more HBase tables.
- MultiTableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- MultiTableOutputFormat.MultiTableRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
Record writer for outputting to multiple HTables.
- MultiTableRecordWriter(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
n * HBaseConfiguration to used n * whether to use write ahead logging.
- MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
-
MultiTableSnapshotInputFormat generalizes
TableSnapshotInputFormat
allowing a MapReduce job to run
over one or more table snapshots, with one or more scans configured for each.
- MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- MultiTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
MultiTableSnapshotInputFormat generalizes
TableSnapshotInputFormat
allowing a MapReduce
job to run over one or more table snapshots, with one or more scans configured for each.
- MultiTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
-
- MultiTableSnapshotInputFormatImpl - Class in org.apache.hadoop.hbase.mapreduce
-
Shared implementation of mapreduce code over multiple table snapshots.
- MultiTableSnapshotInputFormatImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- MultiThreadedClientExample - Class in org.apache.hadoop.hbase.client.example
-
Example on how to use HBase's
Connection
and
Table
in a multi-threaded
environment.
- MultiThreadedClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
-
- MultiThreadedClientExample.ReadExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class to show how to scan some rows starting at a random location.
- MultiThreadedClientExample.SingleWriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class to show how to send a single put.
- MultiThreadedClientExample.WriteExampleCallable - Class in org.apache.hadoop.hbase.client.example
-
Class that will show how to send batches of puts at the same time.
- MultithreadedTableMapper<K2,V2> - Class in org.apache.hadoop.hbase.mapreduce
-
Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper
- MultithreadedTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
- MultithreadedTableMapper.MapRunner - Class in org.apache.hadoop.hbase.mapreduce
-
- MultithreadedTableMapper.SubMapRecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
- MultithreadedTableMapper.SubMapRecordWriter - Class in org.apache.hadoop.hbase.mapreduce
-
- MultithreadedTableMapper.SubMapStatusReporter - Class in org.apache.hadoop.hbase.mapreduce
-
- multiTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- MultiVersionConcurrencyControl - Class in org.apache.hadoop.hbase.regionserver
-
Manages the read/write consistency.
- MultiVersionConcurrencyControl() - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- MultiVersionConcurrencyControl(String) - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- MultiVersionConcurrencyControl(long) - Constructor for class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
Construct and set read point.
- MultiVersionConcurrencyControl.WriteEntry - Class in org.apache.hadoop.hbase.regionserver
-
Write number and whether write has completed given out at start of a write transaction.
- MunkresAssignment - Class in org.apache.hadoop.hbase.util
-
Computes the optimal (minimal cost) assignment of jobs to workers (or other analogous) concepts
given a cost matrix of each pair of job and worker, using the algorithm by James Munkres in
"Algorithms for the Assignment and Transportation Problems", with additional optimizations as
described by Jin Kue Wong in "A New Implementation of an Algorithm for the Optimal Assignment
Problem: An Improved Version of Munkres' Algorithm".
- MunkresAssignment(float[][]) - Constructor for class org.apache.hadoop.hbase.util.MunkresAssignment
-
Construct a new problem instance with the specified cost matrix.
- MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
- MURMUR_HASH3 - Static variable in class org.apache.hadoop.hbase.util.Hash
-
- MurmurHash - Class in org.apache.hadoop.hbase.util
-
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
- MurmurHash() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash
-
- MurmurHash3 - Class in org.apache.hadoop.hbase.util
-
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
- MurmurHash3() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash3
-
- mutableConf - Variable in class org.apache.hadoop.hbase.CompoundConfiguration
-
- MutableFastCounter - Class in org.apache.hadoop.metrics2.lib
-
- MutableFastCounter(MetricsInfo, long) - Constructor for class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
- MutableHistogram - Class in org.apache.hadoop.metrics2.lib
-
A histogram implementation that runs in constant space, and exports to hadoop2's metrics2 system.
- MutableHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- MutableHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- MutableOnlineRegions - Interface in org.apache.hadoop.hbase.regionserver
-
Interface to Map of online regions.
- MutableRangeHistogram - Class in org.apache.hadoop.metrics2.lib
-
Extended histogram implementation with metric range counters.
- MutableRangeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
- MutableRangeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
- MutableRegionInfo - Class in org.apache.hadoop.hbase.client
-
An implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.
- MutableRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Package private constructor used constructing MutableRegionInfo for the first meta regions
- MutableRegionInfo(TableName, byte[], byte[], boolean, long, int, boolean) - Constructor for class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- MutableSegment - Class in org.apache.hadoop.hbase.regionserver
-
A mutable segment in memstore, specifically the active segment.
- MutableSegment(CellSet, CellComparator, MemStoreLAB, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.MutableSegment
-
- MutableSizeHistogram - Class in org.apache.hadoop.metrics2.lib
-
Extended histogram implementation with counters for metric size ranges.
- MutableSizeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- MutableSizeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- MutableTimeHistogram - Class in org.apache.hadoop.metrics2.lib
-
Extended histogram implementation with counters for metric time ranges.
- MutableTimeHistogram(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- MutableTimeHistogram(String, String) - Constructor for class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutator
-
- mutate(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- mutate(Mutation) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- mutate(List<? extends Mutation>) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- mutate(Mutation) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- mutate(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- mutate(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface, REQ, RawAsyncTableImpl.Converter<ClientProtos.MutateRequest, byte[], REQ>, RawAsyncTableImpl.Converter<RESP, HBaseRpcController, ClientProtos.MutateResponse>) - Static method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- mutate(Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mutate(Mutation, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mutate(Mutation, boolean, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mutate(RpcController, ClientProtos.MutateRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Mutate data in a table.
- mutateLabelsRegion(List<Mutation>, OperationStatus[]) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
Adds the mutations to labels region and set the results to the finalOpStatus.
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
- mutateRow(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface, RowMutations, RawAsyncTableImpl.Converter<ClientProtos.MultiRequest, byte[], RowMutations>, Function<RES, RESP>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mutateRow(RowMutations, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Performs multiple mutations atomically on a single row.
- mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- mutateRows(RpcController, MultiRowMutationProtos.MutateRowsRequest, RpcCallback<MultiRowMutationProtos.MutateRowsResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform atomic (all or none) mutations within the region.
- mutateRowsWithLocks(Collection<Mutation>, Collection<byte[]>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform atomic mutations within the region.
- mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- Mutation - Class in org.apache.hadoop.hbase.client
-
- Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
empty construction.
- Mutation(Mutation) - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
- Mutation(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
Construct the mutation with user defined data.
- mutation - Variable in class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
-
- Mutation.CellWrapper - Class in org.apache.hadoop.hbase.client
-
- MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
-
- MutationBatchOperation(HRegion, Mutation[], boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- MutationDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationDeserializer
-
- MutationReplay(ClientProtos.MutationProto.MutationType, Mutation, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
-
- mutations - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- mutations - Variable in class org.apache.hadoop.hbase.client.RowMutations
-
- MutationSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
- MutationSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- MutationSerialization.MutationDeserializer - Class in org.apache.hadoop.hbase.mapreduce
-
- MutationSerialization.MutationSerializer - Class in org.apache.hadoop.hbase.mapreduce
-
- MutationSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationSerializer
-
- MutationType() - Constructor for enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
-
- mutator - Variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
- mutatorMap - Variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- mutex - Variable in class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- mvcc - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- mvcc - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
-
- mvcc - Variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- mvcc - Variable in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- mvccCountingMap - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
-
- mvccCountingMap - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode
-
- mvccReadPoint - Variable in class org.apache.hadoop.hbase.client.Scan
-
The mvcc read point to use when open a scanner.
- MY_ADDRESS - Static variable in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- MY_COLUMN_FAMILY_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_COLUMN_FAMILY_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- MY_FIRST_COLUMN_QUALIFIER - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_FIRST_COLUMN_QUALIFIER - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- MY_NAMESPACE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_NAMESPACE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- MY_ROW_ID - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_ROW_ID - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- MY_SECOND_COLUMN_QUALIFIER - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_SECOND_COLUMN_QUALIFIER - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- MY_TABLE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
- MY_TABLE_NAME - Static variable in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
- myKey - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- mySeqNum - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'P'
- p0 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p1 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p2 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p3 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p4 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p5 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- p6 - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- PackageMarker - Annotation Type in org.apache.hadoop.hbase.metrics
-
This is a dummy annotation that forces javac to produce output for otherwise empty
package-info.java.
- PackagePrivateFieldAccessor - Class in org.apache.hadoop.hbase.client
-
A helper class used to access the package private field in o.a.h.h.client package.
- PackagePrivateFieldAccessor() - Constructor for class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
-
- packet - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- PacketAckData(long, long) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor.PacketAckData
-
- packetDataLen - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.Callback
-
- PAD_WIDTH - Static variable in class org.apache.hadoop.hbase.client.Result
-
- padFront(String, char, int) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Push the input string to the right by appending a character before it, usually a space.
- padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the head of another, zero padded as desired.
- padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Make a new byte array from a subset of bytes at the tail of another, zero padded as desired.
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- pageDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- pageEndPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- PageFilter - Class in org.apache.hadoop.hbase.filter
-
Implementation of Filter interface that limits results to a specific page size.
- PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
-
Constructor that takes a maximum page size.
- pageSize - Variable in class org.apache.hadoop.hbase.filter.PageFilter
-
- pageSize - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- pageSize - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- pageStartPosition - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- pageUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- Paging - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
Utility class for paging for the metrics.
- Paging() - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- paging - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- pair - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
-
A generic class for pairs.
- Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Default constructor.
- Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Constructor
- PairOfSameType<T> - Class in org.apache.hadoop.hbase.util
-
A generic, immutable class for pairs of objects both of type T
.
- PairOfSameType(T, T) - Constructor for class org.apache.hadoop.hbase.util.PairOfSameType
-
Constructor
- PARALLEL_PREPARE_PUT_STORE_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- PARALLEL_PUT_STORE_THREADS_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- PARALLEL_PUT_STORE_THREADS_LIMIT_MIN_COLUMN_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- parallelPreparePutToStoreThreadLimit - Variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- parallelPutCountPrintThreshold - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- parallelPutToStoreThreadLimit - Variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- parallelPutToStoreThreadLimitCheckMinColumnCount - Variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- parallelReplicate(CompletionService<Integer>, ReplicationEndpoint.ReplicateContext, List<List<WAL.Entry>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- parallelSeek(List<? extends KeyValueScanner>, Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Seek storefiles in parallel to optimize IO latency as much as possible
- parallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- parallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
A flag that enables StoreFileScanner parallel-seeking
- ParallelSeekHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handler to seek storefiles in parallel.
- ParallelSeekHandler(KeyValueScanner, Cell, long, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- param - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- param - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- param - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- param - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- param - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- param1 - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- param2 - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- parameters - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
-
- parametersToObject(Procedure<?>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureDescriber
-
- Params(String, String, String, String) - Constructor for class org.apache.hadoop.hbase.client.example.HttpProxyExample.Params
-
- params - Variable in class org.apache.hadoop.hbase.client.SlowLogParams
-
- params - Variable in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- params - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- params - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- params - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
-
- Params() - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- parent - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- parent - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- parent - Variable in class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- parent - Variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Parent class loader.
- parentDirLockSet - Static variable in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
A set used to synchronized parent path clean up.
- parentProcId - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- parentProcId - Variable in class org.apache.hadoop.hbase.procedure2.trace.ProcedureSpanBuilder
-
- parentRegionNames - Variable in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- parents - Variable in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- parentsMap - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- parentsMap - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- parentsToChildrenPairMap - Variable in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- parentsToChildrenPairMap - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- parse(FullHttpRequest) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- parse(String, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- parse(String, List<Field>, boolean) - Static method in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- parse(byte[], int, int) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- parse(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- parse(String) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- parse(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
- parse(Configuration) - Method in class org.apache.hadoop.hbase.zookeeper.ZKMainServer
-
- parseArgs(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- parseArgs(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- parseArguments(String[]) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- parseBackReferenceName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- parseBrowserUserAgents(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- parseCell() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
Extract a Cell.
- parseCell() - Method in class org.apache.hadoop.hbase.codec.CellCodec.CellDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags.CellDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.codec.MessageCodec.MessageDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec.EncryptedKvDecoder
-
- parseCell() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- parseColumn(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Splits a column in family:qualifier
form into separate byte arrays.
- parseColumns(String, int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- parseCommandLine(String[], Configuration) - Static method in class org.apache.hadoop.hbase.rest.RESTServer
-
- parseCommandLine(CommandLine, Options) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- parseCommandLine(CommandLine, Options) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- parseComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Splits a column in comparatorType:comparatorValue form into separate byte arrays
- ParseConstants - Class in org.apache.hadoop.hbase.filter
-
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by
ParseFilter
- ParseConstants() - Constructor for class org.apache.hadoop.hbase.filter.ParseConstants
-
- parseDate(String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Parses the string to a date.
- parseDelimitedFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Parses all the RegionInfo instances from the passed in stream until EOF.
- parseDelimitedFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- ParsedLine(ArrayList<Integer>, byte[]) - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine
-
- ParseException - Exception in org.apache.hadoop.hbase.security.visibility
-
- ParseException() - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- ParseFilter - Class in org.apache.hadoop.hbase.filter
-
This class allows a user to specify a filter via a string The string is parsed using the methods
of this class and a filter object is constructed.
- ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
-
- parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- parseFrom(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- parseFrom(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
- parseFrom(DataInputStream) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Parses an RegionInfo instance from the passed in stream.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- parseFrom(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.client.TableState
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ClusterId
-
Parse the serialized representation of the
ClusterId
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.Filter
-
Concrete implementers can signal a failure condition in their code by throwing an
IOException
.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterList
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
Deprecated.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.LongComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
Parse a serialized representation of
RowFilter
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFrom(DataInputStream) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- parseFrom(byte[]) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker.SwitchStateTracker
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- parseFrom(byte[], TimeRangeTracker.Type) - Static method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- parseFrom(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
- parseFrom(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
-
- parseFrom(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.SnapshotCleanupTracker
-
- parseFromMethod - Variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- parseFromOrNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns A deserialized
RegionInfo
or null if we failed deserialize or passed bytes null
- parseFromOrNull(byte[], int, int) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Returns A deserialized
RegionInfo
or null if we failed deserialize or passed bytes null
- parseFromOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFromOrNull(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseGetLevelArgs(String[], int) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- parseHashType(String) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts String representation of hash function name to a symbolic
constant.
- parseHostname(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseHostname(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Parse the hostname portion of a host-and-port string
- parseInt(String, int, int) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- parseLong(String, long, long) - Static method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
Parse a number and enforce a range.
- parseMasterAddrs(Configuration) - Static method in class org.apache.hadoop.hbase.client.MasterRegistry
-
Deprecated.
Parses the list of master addresses from the provided configuration.
- parseMasterServerName(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
See HBASE-14861.
- parseMergeMinRegionAge(Configuration) - Static method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- parseMergeMinRegionCount(Configuration) - Static method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- parseMergeMinRegionSizeMb(Configuration) - Static method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- parseMessage(String) - Static method in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- parseMethodsToIgnore(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- parseNamespaceResult(Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseNamespaceResult(String, Result, QuotaTableUtil.NamespaceQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- parseOpts(Queue<String>) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- parseParentsBytes(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- parsePB(BucketCacheProtos.BucketCacheEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- parsePB(HFileProtos.FileInfoProto) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Fill our map with content of the pb we read off disk
- parsePeerFrom(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Parse the serialized representation of a peer configuration.
- parsePercentString(String) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- parsePermissionRecord(byte[], Cell, byte[], byte[], boolean, String) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- parsePermissions(byte[], Result, byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Parse and filter permission based on the specified column family, column qualifier and user
name.
- parsePort(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parsePort(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Parse the port portion of a host-and-port string
- parseProtocolArgs(String[], int) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- parseQueryParams(String, int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- parser - Variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- parseRegionInfoFromRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns an HRI parsed from this regionName.
- parseRegionName(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Separate elements of a regionName.
- parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- parseRegionNameOrReturnNull(byte[]) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Separate elements of a regionName.
- parseRegionServerResult(Result, QuotaTableUtil.RegionServerQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseRegionServerResult(String, Result, QuotaTableUtil.RegionServerQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseReplicaIdFromServerColumn(byte[]) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Parses the replicaId from the server column qualifier.
- parseReplicaIdFromServerColumn(byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Parses the replicaId from the server column qualifier.
- parseResult(Result, QuotaTableUtil.QuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseResultToCollection(Result, Collection<QuotaSettings>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseRowKey(byte[], int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
Return starting position and length of row key from the specified line bytes.
- parseRowKeys(String, int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- parseRowRangeParameter(String) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Parse a ServerName from a string
- parseSetLevelArgs(String[], int) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Constructs a filter object given a simple filter expression
- parseSizeString(String) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- parseSnapshotSize(Cell) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
Parses the snapshot size from the given Cell's value.
- parseStartcode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseState - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- ParseState() - Constructor for enum org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator.ParseState
-
- parseTableCFs(byte[]) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Parse bytes into TableCFs.
- parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- parseTableCFsFromConfig(String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
Convert tableCFs string into Map.
- parseTableResult(Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseTableResult(TableName, Result, QuotaTableUtil.TableQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseTimestamp(String, int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- parseUserResult(Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseUserResult(String, Result, QuotaTableUtil.UserQuotasVisitor) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseVersionFrom(byte[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Parse the content of the ${HBASE_ROOTDIR}/hbase.version file.
- parseWALPositionFrom(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- parseWritable(DataInputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Now parse the old Writable format.
- partial - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- partial - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
If true, it means tracker has incomplete information about the active/deleted procedures.
- partialResults - Variable in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- partialResults - Variable in class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- partitionOps(List<ZKUtil.ZKUtilOp>, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- partitions - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- PARTITIONS_FILE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- passesBloomFilter(Scan, SortedSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Checks whether the given scan passes the Bloom filter (if present).
- passesDeleteFamilyBloomFilter(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- passesGeneralRowBloomFilter(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
A method for checking Bloom filters.
- passesGeneralRowColBloomFilter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
A method for checking Bloom filters.
- passesGeneralRowPrefixBloomFilter(Scan) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
A method for checking Bloom filters.
- passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- passesKeyRangeFilter(Scan) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Checks whether the given scan rowkey range overlaps with the current storefile's
- passesTimerangeFilter(TimeRange, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Check if this storeFile may contain keys within the TimeRange that have not expired (i.e.
- PassthroughInvocationHandler(T) - Constructor for class org.apache.hadoop.hbase.monitoring.TaskMonitor.PassthroughInvocationHandler
-
- password - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslClientCallbackHandler
-
- PASSWORD - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
- password - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- password - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslClientAuthenticationProvider.ShadeSaslClientCallbackHandler
-
- PASSWORD_FILE_KEY - Static variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- passwordDatabase - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- passwordDatabase - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler
-
- PASSWORDFILE - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
- passwordFile - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- path - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- path - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Path of file
- path - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
-
May be null if we were passed a stream.
- path - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- path - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- path - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
-
- path - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- path - Variable in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- path - Variable in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- path - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.ZKTask
-
- path - Variable in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- PATH_SPEC_ANY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- pathHelper - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- pathHelper - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- PathHelper(Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- pathName - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- pathPrefix - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- pathSpecs - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- pathToWatch - Variable in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
- pattern - Variable in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- pattern - Variable in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- PATTERN - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
- pattern - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- pattern - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- patternToJoniFlags(int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- pause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- pause - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- pause - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- pause(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- pause(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- pause - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.DelayRetryHandler
-
- PAUSE_TIME_WITH_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- PAUSE_TIME_WITH_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- PAUSE_TIME_WITHOUT_GC_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- PAUSE_TIME_WITHOUT_GC_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- pauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- pauseForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- pauseMonitor - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- pauseMonitor - Variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- pauseMonitor - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- pauseMs - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- pauseMsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BuilderBase
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- pauseNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BuilderBase
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- pauseNsForServerOverloaded - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- pausesWithGc - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- pausesWithGc - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- pausesWithGc - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- pausesWithoutGc - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- pausesWithoutGc - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- pausesWithoutGc - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- pauseTime - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- Payload(V) - Constructor for class org.apache.hadoop.hbase.metrics.impl.RefCountingMap.Payload
-
- PB_WAL_COMPLETE_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- PB_WAL_MAGIC - Static variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- PBCell - Class in org.apache.hadoop.hbase.types
-
An example for using protobuf objects with
DataType
API.
- PBCell() - Constructor for class org.apache.hadoop.hbase.types.PBCell
-
- PBIS(InputStream, int) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
-
- pbkdf128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA1 at 10,000 iterations.
- pbkdf128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied arguments using
PBKDF2WithHmacSHA1 at 10,000 iterations.
- PBType<T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.types
-
- PBType() - Constructor for class org.apache.hadoop.hbase.types.PBType
-
Deprecated.
- PBUF_TRAILER_MINOR_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
HFile minor version that introduced pbuf filetrailer
- peek() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- peek() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- peek() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- peek() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Look at the next Cell in this scanner, but do not iterate scanner.
- peek() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Look at the next Cell in this scanner, but do not iterate the scanner
- peek() - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- peek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- peek() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
Returns the next WAL entry in this stream but does not advance.
- peek() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- peek() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- peek() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- peek() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- peek() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- peek() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range without incrementing position.
- peer - Variable in class org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter
-
- PEER_CONFIG_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- PEER_QUEUE_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- peerAddress - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- peerCache - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- peerClusterId - Variable in class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
-
- peerClusterId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- peerConfig - Variable in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- peerConfig - Variable in class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- peerConfig - Variable in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- peerConfig - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- peerConfigListeners - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- peerConfigUpdated(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- peerConfigUpdated(ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener
-
Callback method for when users update the ReplicationPeerConfig for this peer
- peerConfigUpdated(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- peerData - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- peerData - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- peerFSAddress - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- peerHBaseRootAddress - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- peerId - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ReplicationFuture
-
- peerId - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ReplicationProcedureBiConsumer
-
- peerId - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- peerId - Variable in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- peerId - Variable in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.RefreshPeerCallable
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- peerID - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- peerID - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- peerId - Variable in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- peerKey - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- peerLocks - Variable in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- peerManager - Variable in class org.apache.hadoop.hbase.master.cleaner.ReplicationBarrierCleaner
-
- peerMap - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- PeerOperationType() - Constructor for enum org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface.PeerOperationType
-
- PeerProcedureHandler - Interface in org.apache.hadoop.hbase.replication.regionserver
-
A handler for modifying replication peer in peer procedures.
- peerProcedureHandler - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- PeerProcedureHandlerImpl - Class in org.apache.hadoop.hbase.replication.regionserver
-
- PeerProcedureHandlerImpl(ReplicationSourceManager) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- PeerProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
-
- PeerProcedureInterface.PeerOperationType - Enum in org.apache.hadoop.hbase.master.procedure
-
- PeerQueue - Class in org.apache.hadoop.hbase.master.procedure
-
- PeerQueue(String, LockStatus) - Constructor for class org.apache.hadoop.hbase.master.procedure.PeerQueue
-
- peerQuorumAddress - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- PeerRegionServerListener(HBaseReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
-
- peerRunQueue - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- peers - Variable in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- PEERS_STATE_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- PEERS_STATE_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- PEERS_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- PEERS_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- peerSeqNum - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- peersLock - Variable in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- peerSnapshotName - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- peerSnapshotTmpDir - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- peersQueueSize - Variable in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- peersSelected - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- PeerState() - Constructor for enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
-
- peerState - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- peerStateNodeName - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
The name of the znode that contains the replication status of a remote slave (i.e.
- peerStorage - Variable in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- peerStorage - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- peerStorage - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- peerStorage - Variable in class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
-
- peersZNode - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
The name of the znode that contains a list of all remote slave (i.e.
- peersZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- peerTableName - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- pending - Variable in class org.apache.hadoop.hbase.zookeeper.PendingWatcher
-
- pendingAssignQueue - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- pendingConnections - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
-
Deprecated.
- pendingDelete - Variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- pendingLatch - Variable in class org.apache.hadoop.hbase.zookeeper.InstancePending
-
- pendingRequests - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- pendingRequests - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- PendingWatcher - Class in org.apache.hadoop.hbase.zookeeper
-
Placeholder of a watcher which might be triggered before the instance is not yet created.
- PendingWatcher() - Constructor for class org.apache.hadoop.hbase.zookeeper.PendingWatcher
-
- PER_BLOCK_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- PERCENT_FILES_LOCAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- PERCENT_FILES_LOCAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- PERCENT_FILES_LOCAL_SECONDARY_REGIONS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- PERCENT_FILES_LOCAL_SECONDARY_REGIONS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- percentFileLocal - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- percentFileLocalSecondaryRegions - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- PerClientRandomNonceGenerator - Class in org.apache.hadoop.hbase.client
-
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random
numbers as nonces.
- PerClientRandomNonceGenerator() - Constructor for class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- performBulkLoad(Admin, Table, RegionLocator, Deque<LoadIncrementalHFiles.LoadQueueItem>, ExecutorService, SecureBulkLoadClient, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- performCompaction(Compactor.FileDetails, InternalScanner, CellSink, long, boolean, ThroughputController, CompactionRequestImpl, CompactionProgress) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
Performs compaction on a column family with the mob flag enabled.
- performCompaction(Compactor.FileDetails, InternalScanner, CellSink, long, boolean, ThroughputController, CompactionRequestImpl, CompactionProgress) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Performs the compaction.
- performCostlyOperation() - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- performFlush(InternalScanner, CellSink, ThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.StoreFlusher
-
Performs memstore flush, writing data from scanner into sink.
- performMajorCompactionInBatches(Admin, TableDescriptor, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- performMobFlush(MemStoreSnapshot, long, InternalScanner, StoreFileWriter, MonitoredTask, ThroughputController, Consumer<Path>) - Method in class org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
-
Flushes the cells in the mob store.
- performOnSuperuser(String, User, String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Check if caller is granting or revoking superusers's or supergroups's permissions.
- performOnSuperuser(String, User, String) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- period - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- period - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- period - Variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- period - Variable in class org.apache.hadoop.hbase.ScheduledChore
-
Scheduling parameters.
- period - Variable in class org.apache.hadoop.hbase.util.Sleeper
-
- PERIOD_COMPACTION - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- PERIOD_FLUSH - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- PERIODIC_REFRESH_INTERVAL_SECS - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- PERIODIC_REFRESH_INTERVAL_SECS_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- PERIODIC_ROLL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- periodicalFlushTimer - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- periodicalFlushTimer - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- periodicExecute(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.DeadServerMetricRegionChore
-
- periodicExecute(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionChore
-
- periodicExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- periodicExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
-
- periodicFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Check for flushes
- periodicFlushTask - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- periodicFlushTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- periodicFlushTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
-
- PeriodicMemStoreFlusher(int, HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- periodicRefreshMs - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- periodicRoll() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- periodicRollForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- periodicRollMsec - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- periodToLog - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- PERM_ALL_ACCESS - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- PERM_ALL_ACCESS - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- PERM_HIDDEN - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- Permission - Class in org.apache.hadoop.hbase.security.access
-
Base permissions instance representing the ability to perform a given set of actions.
- Permission() - Constructor for class org.apache.hadoop.hbase.security.access.Permission
-
Empty constructor for Writable implementation.
- Permission(Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
-
- Permission(byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.Permission
-
- permission - Variable in class org.apache.hadoop.hbase.security.access.UserPermission
-
- Permission.Action - Enum in org.apache.hadoop.hbase.security.access
-
- Permission.Builder - Class in org.apache.hadoop.hbase.security.access
-
- Permission.Scope - Enum in org.apache.hadoop.hbase.security.access
-
- PermissionCache() - Constructor for class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- permissionGranted(String, User, Permission.Action, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- permissionGranted(String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Check the current user for authorization to perform a specific action against the given set of
row data.
- permissionGranted(AccessController.OpType, User, RegionCoprocessorEnvironment, Map<byte[], ? extends Collection<?>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Check the current user for authorization to perform a specific action against the given set of
row data.
- permissionGranted(String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- PermissionStorage - Class in org.apache.hadoop.hbase.security.access
-
Maintains lists of permission grants to users and groups to allow for authorization checks by
AccessController
.
- PermissionStorage() - Constructor for class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- perRegionServerBufferQueueSize - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- perServerFailuresCount - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- persist - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
Indicate whether we need to persist the procedure to ProcedureStore after execution.
- persistAll() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- persistAll() - Method in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
-
- persistAll() - Method in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
Add all slowLog events to system table.
- persistAll(NamedQueuePayload.NamedQueueEvent) - Method in class org.apache.hadoop.hbase.namequeues.LogEventHandler
-
Add all in memory queue records to system table.
- persistAll(NamedQueuePayload.NamedQueueEvent) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
-
Add all in memory queue records to system table.
- persistAll() - Method in interface org.apache.hadoop.hbase.namequeues.NamedQueueService
-
Add all in memory queue records to system table.
- persistAndWake(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- persistencePath - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- PersistentIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
A class implementing PersistentIOEngine interface supports file integrity verification for
BucketCache
which use persistent IOEngine
- PersistentIOEngine(String...) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
-
- PersistentIOEngine.DuFileCommand - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
- persistentOutput - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- persistSnapshotSizeChanges(Map<String, Long>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Reads the current size for each snapshot to update, generates a new update based on that value,
and then writes the new update.
- persistSnapshotSizes(Table, List<FileArchiverNotifierImpl.SnapshotWithSize>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
Writes the snapshot sizes to the provided table
.
- persistSnapshotSizesForNamespaces(Map<String, Long>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Writes the size used by snapshots for each namespace to the quota table.
- persistToFile() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- persistToMeta(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- perStoreMemstoreOnlyReadCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- perStoreMixedReadCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- perTableAppendCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- perTableAppendSize - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- perTableFailuresCount - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- perTableReadLatency - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- pgd - Static variable in class org.apache.hadoop.hbase.mapred.Driver
-
- PHOENIX - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- physical - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- pickLeastLoadedFNServer(BalancerClusterState, List<ServerName>, int) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLoadPicker
-
- pickLeastLoadedServer(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLoadPicker
-
- pickLeastLoadedServer(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.LoadCandidateGenerator
-
- pickLowestLocalRegionOnServer(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLocalityPicker
-
- pickMostLoadedServer(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer.FavoredNodeLoadPicker
-
- pickMostLoadedServer(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.LoadCandidateGenerator
-
- pickOtherRandomRack(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- pickOtherRandomServer(BalancerClusterState, int) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- pickRandomRack(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- pickRandomRegion(BalancerClusterState, int, double) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
From a list of regions pick a random one.
- pickRandomRegions(BalancerClusterState, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- pickRandomServer(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.CandidateGenerator
-
- pid - Variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- PING_CALL_ID - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- pipeline - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- pipeline - Variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- PipelineController() - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
-
- pipelineThreshold - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- placePrimaryRSAsRoundRobin(Map<ServerName, List<RegionInfo>>, Map<RegionInfo, ServerName>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- placeSecondaryAndTertiaryRS(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
For regions that share the primary, avoid placing the secondary and tertiary on a same RS.
- PlainTextMessageBodyProducer - Class in org.apache.hadoop.hbase.rest.provider.producer
-
An adapter between Jersey and Object.toString().
- PlainTextMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- plan - Variable in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- planSkipped(NormalizationPlan.PlanType) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
Call-back for the case where plan couldn't be executed due to constraint violation, such as
namespace quota.
- planSkipped(NormalizationPlan.PlanType) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- PlanType() - Constructor for enum org.apache.hadoop.hbase.master.normalizer.NormalizationPlan.PlanType
-
- PleaseHoldException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server was shut down and restarted so fast
that the master still hasn't processed the server shutdown of the first instance, or when master
is initializing and client call admin operations, or when an operation is performed on a region
server that is still starting.
- PleaseHoldException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- PleaseRestartMasterException - Exception in org.apache.hadoop.hbase
-
Thrown if the master requires restart.
- PleaseRestartMasterException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseRestartMasterException
-
- PLUGGABLE_CALL_QUEUE_CLASS_NAME - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- PLUGGABLE_CALL_QUEUE_WITH_FAST_PATH_ENABLED - Static variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- PluggableBlockingQueue - Class in org.apache.hadoop.hbase.ipc
-
Abstract class template for defining a pluggable blocking queue implementation to be used by the
'pluggable' call queue type in the RpcExecutor.
- PluggableBlockingQueue(int, PriorityFunction, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
-
- PluggableRpcQueueNotFound - Exception in org.apache.hadoop.hbase.ipc
-
Internal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call
queue type.
- PluggableRpcQueueNotFound(String) - Constructor for exception org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFound
-
- pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- plus(FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- policy - Variable in class org.apache.hadoop.hbase.http.HttpConfig
-
- Policy() - Constructor for enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- policy - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- policy - Variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- policy - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- POLICY_REFRESHER_CHORE_DELAY_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_DELAY_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_PERIOD_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_REPORT_PERCENT_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_REPORT_PERCENT_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_TIMEUNIT_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- POLICY_REFRESHER_CHORE_TIMEUNIT_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- policyName - Variable in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
Poll for the first completed task whether it is a success or execution exception.
- poll() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Returns The next element in this queue, or null
if the queue is empty.
- poll() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Returns The next element in this queue, or null
if the queue is empty.
- poll() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- poll() - Method in class org.apache.hadoop.hbase.master.procedure.FairQueue
-
- poll() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- poll() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- poll(long) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- poll() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Fetch one Procedure from the queue
- poll(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Fetch one Procedure from the queue
- poll(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- poll() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- poll() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- poll() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- poll(long, TimeUnit) - Method in class org.apache.hadoop.hbase.util.StealJobQueue
-
- pollCache() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- pollCalls - Variable in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- pollFirst() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- pollFirst() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- pollFirstEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- pollFirstEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- pollForFirstSuccessfullyCompletedTask(long, TimeUnit, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
Poll for the first successfully completed task whose completed order is in startIndex,
endIndex(exclusive) range
- pollForSpecificCompletedTask(long, TimeUnit, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
Poll for the Nth completed task (index starts from 0 (the 1st), 1 (the second)...)
- pollKeyPress() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- pollKeyPress() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- pollKeyPress() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Returns The last element in this queue, or null
if the queue is empty.
- pollLast() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Returns The last element in this queue, or null
if the queue is empty.
- pollLast() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- pollLast() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- pollLastEntry() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- pollLastEntry() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- pollRealKV() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Fetches the top sub-scanner from the priority queue, ensuring that a real seek has been done on
it.
- pool - Variable in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- pool - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- pool - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- pool - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- pool - Variable in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- pool - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- pool - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- pool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the default executor pool defined by the hbase.htable.threads.*
configuration
values.
- pool - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- pool - Variable in class org.apache.hadoop.hbase.client.HTable
-
- pool - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- pool - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- pool - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- pool - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- pool - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- pool - Variable in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- pool - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- pool - Variable in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- pool - Variable in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
- pool - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- pool - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- pool - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- pool - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- POOL_INITIAL_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- POOL_MAX_SIZE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
- POOL_SIZE - Static variable in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
-
- poolAllocationBytes - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- POOLED_ALLOCATOR_TYPE - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- PoolMap<K,V> - Class in org.apache.hadoop.hbase.util
-
The PoolMap
maps a key to a collection of values, the elements of which are managed
by a pool.
- PoolMap(PoolMap.PoolType, int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap
-
- PoolMap.Pool<R> - Interface in org.apache.hadoop.hbase.util
-
- PoolMap.PoolResourceSupplier<R> - Interface in org.apache.hadoop.hbase.util
-
- PoolMap.PoolType - Enum in org.apache.hadoop.hbase.util
-
- PoolMap.RoundRobinPool<R> - Class in org.apache.hadoop.hbase.util
-
- PoolMap.ThreadLocalPool<R> - Class in org.apache.hadoop.hbase.util
-
- poolMaxSize - Variable in class org.apache.hadoop.hbase.util.PoolMap
-
- poolNumber - Static variable in class org.apache.hadoop.hbase.DaemonThreadFactory
-
- pools - Variable in class org.apache.hadoop.hbase.util.PoolMap
-
- poolSizePercentage - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- poolType - Variable in class org.apache.hadoop.hbase.util.PoolMap
-
- PoolType() - Constructor for enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- popArguments(Stack<ByteBuffer>, Stack<Filter>) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Pops an argument from the operator stack and the number of arguments required by the operator
from the filterStack and evaluates them
- popReadyHandler() - Method in class org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
-
Returns Pop a Handler instance if one available ready-to-go or else return null.
- populateBalanceRSGroupResponse(RSGroupAdminProtos.BalanceRSGroupResponse.Builder, BalanceResponse) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupProtobufUtil
-
- populateConnectionAttributes(Map<AttributeKey<?>, Object>, ClusterConnection) - Static method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- populateConnectionAttributes(Map<AttributeKey<?>, Object>, AsyncConnectionImpl) - Static method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
Static utility method that performs the primary logic of this builder.
- populateConnectionAttributes(Map<AttributeKey<?>, Object>, Supplier<String>, Supplier<User>) - Static method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
Static utility method that performs the primary logic of this builder.
- populateFromJoinedHeap(List<Cell>, ScannerContext) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
Returns true if more cells exist after this batch, false if scanner is done
- populateLoadQueue(Deque<LoadIncrementalHFiles.LoadQueueItem>, Map<byte[], List<Path>>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Populate the Queue with given HFiles
- populateMethodDescriptorAttributes(Map<AttributeKey<?>, Object>, Descriptors.MethodDescriptor) - Static method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
Static utility method that performs the primary logic of this builder.
- populatePut(byte[], ImportTsv.TsvParser.ParsedLine, Put, int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- populateReadTableTimeoutsMap(String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- populateRegionPerLocationFromServer(int[][], Int2IntCounterMap[], int[][]) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- populateResult(List<Cell>, KeyValueHeap, ScannerContext, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is
reached, or remainingResultSize (if not -1) is reaced
- populateStubs(Set<ServerName>) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- populateTableNameAttributes(Map<AttributeKey<?>, Object>, TableName) - Static method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
-
Static utility method that performs the primary logic of this builder.
- port - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- port() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- port - Variable in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- port - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- port - Variable in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- port - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- port - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- port - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
-
- port - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- port - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- port - Static variable in class org.apache.hadoop.hbase.thrift2.DemoClient
-
- port - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- port - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- PORT_FIELD - Static variable in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- PORT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- pos - Variable in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
- pos - Variable in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
- pos - Variable in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- POS_INF - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- POS_LARGE - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- POS_MED_MAX - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- POS_MED_MIN - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- POS_SMALL - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- Position() - Constructor for enum org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
-
- position() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns this ByteBuff's current position
- position(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Sets this ByteBuff's position to the given value.
- position() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns this MBB's current position
- position(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Sets this MBB's position to the given value.
- position() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- position(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- position - Variable in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
The current index into the range.
- position - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- PositionedByteRange - Interface in org.apache.hadoop.hbase.util
-
Extends
ByteRange
with additional methods to support tracking a consumers position within
the viewport.
- positionForNextBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Set our selves up for the next 'next' invocation, set up next block.
- positionThisBlockBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Set the position on current backing blockBuffer.
- positionToByteArray(long) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- positiveJitterRate() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for POST create namespace with properties specified.
- post(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- post(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
-
- post(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a abortProcedure request has been processed.
- postAbortProcedure() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postAction(BalanceAction) - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
Called once per cluster Action to give the cost function an opportunity to update it's state.
- postAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after add a replication peer
- postAddReplicationPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a new region server group is added
- postAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, Result, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after Append
- postAppend(Append, Result, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postAppend(WAL.Entry, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- postAppend(long, long, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- postAppend(long, long, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post append to the writer.
- postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a list of new cells has been created during an append operation, but before they
are committed to the WAL or memstore.
- postAppendBeforeWAL(Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postApply(GlobalQuotaSettingsImpl) - Method in interface org.apache.hadoop.hbase.quotas.MasterQuotaManager.SetQuotaOperations
-
- postAssign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region assignment has been requested.
- postAssign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBalance(ObserverContext<MasterCoprocessorEnvironment>, BalanceRequest, List<RegionPlan>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the balancing plan has been submitted.
- postBalance(BalanceRequest, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, BalanceRequest, BalanceResponse) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a region server group is removed
- postBalanceRSGroup(String, BalanceRequest, BalanceResponse) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the flag to enable/disable balancing has changed.
- postBalanceSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called after applying a batch of Mutations on a region.
- postBatchMutate(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- postBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postBatchMutate(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
The hook to be executed after the process() and applying the Mutations to region.
- postBatchMutateIndispensably(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the completion of batch put/delete/increment/append and will be called even if the
batch operation fails.
- postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>, Map<byte[], List<Path>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after bulkLoadHFile.
- postBulkLoadHFile(List<Pair<byte[], String>>, Map<byte[], List<Path>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCellEncode(int, int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodingState
-
- postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after checkAndMutate
- postCheckAndMutate(CheckAndMutate, CheckAndMutateResult) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after clearing compaction queues
- postClearCompactionQueues() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after clear dead region servers.
- postClearDeadServers(List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot clone operation has been requested.
- postCloneSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCloneSnapshot(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Action after cloning from snapshot.
- postClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as closed to the master.
- postClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region is closed
- postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postCloseRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after moving bulk loaded hfile to region directory.
- postCommitStoreFile(byte[], Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after compaction has completed and the new store file has been moved in to place.
- postCompact(HStore, HStoreFile, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the store compaction has completed.
- postCompactScannerOpen(CompactionRequestImpl, ScanType, InternalScanner, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Calls coprocessor, if any, to create scanners - after normal scanner creation.
- postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends StoreFile>, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- postCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends StoreFile>, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the
StoreFile
s to compact have been selected from the available
candidates.
- postCompactSelection(HStore, List<HStoreFile>, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called after the
HStoreFile
s to be compacted have been selected from the available
candidates.
- postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postCompletedCreateTableAction(TableDescriptor, RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
deletes a table.
- postCompletedDeleteTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the disableTable operation has been requested.
- postCompletedDisableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the enableTable operation has been requested.
- postCompletedEnableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedMergeRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Post merge region action
- postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
called after the regions merge.
- postCompletedMergeRegionsAction(RegionInfo[], RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after completing merge regions operation
- postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after to modifying a table's properties.
- postCompletedModifyTableAction(TableName, TableDescriptor, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the snapshot operation has been completed.
- postCompletedSnapshotAction(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region is split.
- postCompletedSplitRegionAction(RegionInfo, RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just after a split
- postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after
HMaster
truncates a table.
- postCompletedTruncateTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postCreate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createNamespace operation has been requested.
- postCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after the replication endpoint is instantiated.
- postCreateReplicationEndPoint(ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment>, ReplicationEndpoint) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplication
-
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- postCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the createTable operation has been requested.
- postCreateTable(TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after decommission region servers.
- postDecommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client deletes a value.
- postDelete(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- postDelete(Delete, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteNamespace operation has been requested.
- postDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the delete snapshot operation has been requested.
- postDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the deleteTable operation has been requested.
- postDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- postDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Action after disabling table.
- postDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after disable a replication peer n * @param peerId a short name that identifies the peer
- postDisableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the disableTable operation has been requested.
- postDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postEnable(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Action after enabling table.
- postEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after enable a replication peer n * @param peerId a short name that identifies the peer
- postEnableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the enableTable operation has been requested.
- postEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postEncoding(HFileBlockEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
-
- postEncoding(BlockType) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- postEncoding(BlockType) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Do any action that needs to be performed after the encoding.
- postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
-
Called after an Endpoint service method is invoked.
- postEndpointInvocation(Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message, Message.Builder) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postEnvCall() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperation
-
- postExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after executing procedures
- postExecuteProcedures() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client tests for existence using a Get.
- postExists(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postFinish() - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- postFinish() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the memstore is flushed to disk.
- postFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a Store's memstore is flushed to disk.
- postFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a memstore flush n
- postFlush(HStore, HStoreFile, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a memstore flush n
- postGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment>, ClusterMetrics) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after get cluster status.
- postGetClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetLocks(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getLocks request has been processed.
- postGetLocks(List<LockedResource>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getNamespaceDescriptor request has been processed.
- postGetNamespaceDescriptor(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- postGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client performs a Get
- postGetProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getProcedures request has been processed.
- postGetProcedures(List<Procedure<?>>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after get the configured ReplicationPeerConfig for the specified peer n * @param peerId
a short name that identifies the peer
- postGetReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableDescriptors request has been processed.
- postGetTableDescriptors(List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a getTableNames request has been processed.
- postGetTableNames(List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, String, TableName, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting user permissions.
- postGetUserPermissions(String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after granting user permissions.
- postGrant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, List<Permission>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after checking if user has permissions.
- postHasUserPermissions(String, List<Permission>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, Result, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after increment
- postIncrement(Increment, Result, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a list of new cells has been created during an increment operation, but before
they are committed to the WAL or memstore.
- postIncrementBeforeWAL(Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, Mutation, List<Pair<Cell, Cell>>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postInstantiateDeleteTracker(DeleteTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment>, DeleteTracker) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after getting if is rpc throttle enabled.
- postIsRpcThrottleEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after list decommissioned region servers.
- postListDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listNamespaceDescriptors request has been processed.
- postListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postListNamespaces(ObserverContext<MasterCoprocessorEnvironment>, List<String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a listNamespaces request has been processed.
- postListNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListNamespaces(ObserverContext<MasterCoprocessorEnvironment>, List<String>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after list replication peers.
- postListReplicationPeers(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after listSnapshots request has been processed.
- postListSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after heartbeat to a lock.
- postLockHeartbeat(LockProcedure, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL has been archived.
- postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- postLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL has been rolled.
- postLogRoll(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- postLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- postMasterStartupInitialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
If balancer needs to do initialization after Master has started up, lets do that here.
- postMasterStartupInitialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- postMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the master local region memstore is flushed to disk.
- postMasterStoreFlush() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment>, Store) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the in memory compaction is finished.
- postMemStoreCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after in memory compaction.
- postMergeRegions(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
called after merge regions request.
- postMergeRegions(RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMergeRegionsCommit(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Post merge region action
- postMergeRegionsCommit(RegionInfo[], RegionInfo, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after merge regions operation writes the new region to hbase:meta
- postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after META step as part of regions merge transaction.
- postModify(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Action after modifying table.
- postModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after modifying a family store file tracker.
- postModifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyNamespace operation has been requested.
- postModifyNamespace(NamespaceDescriptor, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the modifyTable operation has been requested.
- postModifyTable(TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after modifying a table's store file tracker.
- postModifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMove(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region move has been requested.
- postMove(RegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are moved to target region server group
- postMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment>, RegionObserver.MutationType, Mutation, Cell, Cell) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the region is reported as open to the master.
- postOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked after a region open
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Region related hooks
- PostOpenDeployContext(HRegion, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- postOpenDeployTasks(RegionServerServices.PostOpenDeployContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Tasks to perform after region open to complete deploy of region on regionserver
- PostOpenDeployTasksThread(HRegion, Server, RegionServerServices, AtomicBoolean, long) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- postOperationFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
Called after the operation is terminated with a failure.
- postOperationFailure(IOException, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- postOperationResult(Void, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.DeleteTableFuture
-
- postOperationResult(Void, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ModifyTableFuture
-
- postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
Called after the operation is completed and the result fetched.
- postOperationResult(V, long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.TableFuture
-
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.DisablePeerProcedure
-
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.EnablePeerProcedure
-
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
Called before we finish the procedure.
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- postPeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- postProcess(HRegion, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- postProcess(HRegion, WALEdit, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
The hook to be executed after process() and applying the Mutations to region.
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client stores a value.
- postPut(Put, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postPut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment>, ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after recommission region server.
- postRecommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRefreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- postRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region has been marked offline.
- postRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after remove a replication peer n * @param peerId a short name that identifies the peer
- postRemoveReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a region server group is removed
- postRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after servers are removed from rsgroup
- postRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after rename rsgroup.
- postRenameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after replaying WALs for this region.
- postReplayWALs(RegionInfo, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
- postReplicateLogEntries() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postRequestLock(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, RegionInfo[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after new LockProcedure is queued.
- postRequestLock(String, TableName, RegionInfo[], LockType, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after a snapshot restore operation has been requested.
- postRestoreSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after revoking user permissions.
- postRevoke(UserPermission) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postRollBackMergeRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Action after rollback a merge table regions action.
- postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after the roll back of the regions merge.
- postRollBackMergeRegionsAction(RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked after rollback merge regions operation
- postRollBackSplitRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Action after rollback a split table region action.
- postRollBackSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after the roll back of the split region is completed
- postRollBackSplitRegionAction(User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just after the rollback of a failed split
- postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called after executing user request to roll a region server WAL.
- postRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client closes a scanner.
- postScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, Cell, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
- postScannerFilterRow(InternalScanner, Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
- postScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client asks for the next row on a scanner.
- postScannerNext(InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after the client opens a new scanner.
- postScannerOpen(Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the namespace is stored.
- postSetNamespaceQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the region server is stored.
- postSetRegionServerQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after setting split / merge switch
- postSetSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the table is stored.
- postSetTableQuota(TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified table is stored.
- postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the quota for the user on the specified namespace is stored.
- postSetUserQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(String, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSetUserQuota(String, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postShipEdits(List<WAL.Entry>, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- postShipEdits(List<WAL.Entry>, int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Call this after the shipper thread ship some entries to peer cluster.
- postSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the snapshot operation has been requested.
- postSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Perform tasks needed after the completion of snapshot operation.
- postSplitRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Post split region actions
- postStart() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
- postStart() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Called after start is called.
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately after an active master instance has completed initialization.
- postStartMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- postStartMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Master related hooks
- postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment>, Region.Operation) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postStartRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- postStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postStoreFileReaderOpen(ReaderContext, CacheConfig, StoreFileReader) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- postSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after switching exceed throttle quota state.
- postSwitchExceedThrottleQuota(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment>, boolean, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after switching rpc throttle enabled state.
- postSwitchRpcThrottle(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postSync() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
-
triggered when the store sync is completed.
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- postSync(long, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- postSync(long, int) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
For notification post writer sync.
- postTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the table memstore is flushed to disk.
- postTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postTruncate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the truncateTable operation has been requested.
- postTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- postUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after the region unassignment has been requested.
- postUnassign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Issue any post update synchronization and tests
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- postUpdate(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- postUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after update peerConfig for the specified peer
- postUpdateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment>, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called after update rsgroup config.
- postUpdateRSGroupConfig(String, Map<String, String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called after a
WALEdit
replayed for this region.
- postWALRestore(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- postWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called after rolling the current WAL
- postWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Called after rolling the current WAL
- postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
- postWALWrite(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, long) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a abortProcedure request has been processed.
- preAbortProcedure(ProcedureExecutor<MasterProcedureEnv>, long) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment>, long) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- pread - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- preadAllBytes - Variable in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- preAddPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before add a replication peer
- preAddReplicationPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new region server group is added
- preAddRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preadMaxBytes - Variable in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- preadMaxBytes - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- preadWithExtra(ByteBuff, FSDataInputStream, long, int, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read from an input stream at least necessaryLen
and if possible,
extraLen
also if available.
- preadWithExtra(ByteBuff, FSDataInputStream, long, int, int, boolean) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read from an input stream at least necessaryLen
and if possible,
extraLen
also if available.
- preadWithExtraDirectly(ByteBuff, FSDataInputStream, long, int, int, boolean) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
- preadWithExtraOnHeap(ByteBuff, FSDataInputStream, long, int, int, boolean) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
- preambleBuffer - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Append.
- preAppend(Append, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preAppend(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Append) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preAppendAfterRowLock(Append) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preApply(GlobalQuotaSettingsImpl) - Method in interface org.apache.hadoop.hbase.quotas.MasterQuotaManager.SetQuotaOperations
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to assigning a specific region.
- preAssign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preAssign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>, BalanceRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to requesting rebalancing of the cluster regions, though after the initial checks
for regions in transition and the balance switch flag.
- preBalance(BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preBalance(ObserverContext<MasterCoprocessorEnvironment>, BalanceRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBalanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Called before actually executing balanceCluster.
- preBalanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a region server group is removed
- preBalanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying the flag used to enable/disable region balancing.
- preBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
This will be called for every batch mutation operation happening at the server.
- preBatchMutate(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- preBatchMutate(MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preBatchMutate(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
The hook to be executed after the process() but before applying the Mutations to region.
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preBatchMutate(ObserverContext<RegionCoprocessorEnvironment>, MiniBatchOperationInProgress<Mutation>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before bulkLoadHFile.
- preBulkLoadHFile(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This method should only be called from Region.
- preBulkLoadHFile(List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment>, List<Pair<byte[], String>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Verifies user has CREATE or ADMIN privileges on the Column Families involved in the
bulkLoadHFile request.
- preCheck() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- preCheck() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- preCheck() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- preCheck() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- preCheck(Row) - Method in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
- preCheck() - Method in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- preCheck() - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- preCheck(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Check before the delete logic.
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- preCheck(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
-
- preCheck() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Delete, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Delete, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndMutate
- preCheckAndMutate(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preCheckAndMutateAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, CheckAndMutate, CheckAndMutateResult) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before checkAndDelete but after acquiring rowlock.
- preCheckAndMutateAfterRowLock(CheckAndMutate) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], Filter, Put, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, byte[], byte[], byte[], CompareOperator, ByteArrayComparable, Put, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCheckAndTryRestoreSFT(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- preCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- preClean() - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Used to do some initialize work before every period clean
- preClean() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call.
- preCleanupBulkLoad(User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Authorization security check for SecureBulkLoadProtocol.cleanupBulkLoad()
- preClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before clearing compaction queues
- preClearCompactionQueues() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before clear dead region servers.
- preClearDeadServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is cloned.
- preCloneSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCloneSnapshot(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Action before cloning from snapshot.
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as closed to the master.
- preClose(boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region is closed
- preClose(ObserverContext<RegionCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCloseWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Subclasses override this method to be called before we close the give writer.
- preCloseWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before moving bulk loaded hfile to region directory.
- preCommitStoreFile(String, Path, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate the filename in the main family store directory for moving the file from a build/temp
location.
- preCommitStoreFile(byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment>, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationObserver
-
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Subclasses override this method to be called at the end of a successful sequence of append; all
appends are processed before this method is called.
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
-
- preCommitWriters() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- preCommitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to writing the
StoreFile
s selected for compaction into a new
StoreFile
.
- preCompact(HStore, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to rewriting the store files selected for compaction
- preCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, ScanType, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanType, ScanOptions, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanType, ScanOptions, CompactionLifeCycleTracker, CompactionRequest) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanType, ScanOptions, CompactionLifeCycleTracker, CompactionRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for compaction.
- preCompactScannerOpen(CompactionRequestImpl, ScanType, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- preCompactScannerOpen(HStore, ScanType, CompactionLifeCycleTracker, CompactionRequest, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to opening store scanner for compaction.
- preCompactSelection(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends StoreFile>, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called prior to selecting the
StoreFiles
to compact from the list of
available candidates.
- preCompactSelection(HStore, List<HStoreFile>, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called prior to selecting the
HStoreFile
s for compaction from the list of currently
available candidates.
- preCreate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new namespace is created by
HMaster
.
- preCreateNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
.
- preCreateTable(TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Observer implementations
- preCreateTable(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
- preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new table is created by
HMaster
.
- preCreateTableAction(TableDescriptor, RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor, RegionInfo[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before we create the region infos for this table.
- preCreateTableRegionsInfos(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before decommission region servers.
- preDecommissionRegionServers(List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment>, List<ServerName>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client deletes a value.
- preDelete(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- preDelete(Delete, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a namespace
- preDeleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is deleted.
- preDeleteSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a table.
- preDeleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDeleteTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
deletes a table.
- preDeleteTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDisable(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Action before disabling table.
- preDisablePeer(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- preDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before disable a replication peer n * @param peerId a short name that identifies the
peer
- preDisableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to disabling a table.
- preDisableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preDisableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preDisableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to disabling a table.
- preDisableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- PreemptedWALSplitException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitException
-
- PreemptiveFastFailException - Exception in org.apache.hadoop.hbase.exceptions
-
- PreemptiveFastFailException(long, long, long, ServerName) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- PreemptiveFastFailException(long, long, long, ServerName, boolean) - Constructor for exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- PreemptiveFastFailInterceptor - Class in org.apache.hadoop.hbase.client
-
- PreemptiveFastFailInterceptor(Configuration) - Constructor for class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- preemptiveSync(ProtobufLogWriter) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Run a sync after opening to set up the pipeline.
- preEnable(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Action before enabling table.
- preEnablePeer(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- preEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before enable a replication peer n * @param peerId a short name that identifies the peer
- preEnableReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to enabling a table.
- preEnableTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preEnableTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preEnableTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to enabling a table.
- preEnableTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message) - Method in interface org.apache.hadoop.hbase.coprocessor.EndpointObserver
-
Called before an Endpoint service method is invoked.
- preEndpointInvocation(Service, String, Message) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment>, Service, String, Message) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before executing procedures
- preExecuteProcedures() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client tests for existence using a Get.
- preExists(Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preExists(ObserverContext<RegionCoprocessorEnvironment>, Get, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
- PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- PREFETCH_BLOCKS_ON_OPEN_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- PREFETCH_BLOCKS_ON_OPEN_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to prefetch all blocks of a given file into the block cache when the file is
opened.
- prefetchComplete() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- prefetchComplete() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Returns false if block prefetching was requested for this file and has not completed, true
otherwise
- prefetchCondition() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- prefetchDelayMillis - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
Delay before beginning prefetch
- prefetchDelayVariation - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
Variation in prefetch delay times, to mitigate stampedes
- prefetchedHeader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Cache of the NEXT header after this.
- PrefetchedHeader() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.PrefetchedHeader
-
- PrefetchExecutor - Class in org.apache.hadoop.hbase.io.hfile
-
- PrefetchExecutor() - Constructor for class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- prefetchExecutorPool - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
Executor pool shared among all HFiles for block prefetch
- prefetchFutures - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
Futures for tracking block prefetch activity
- prefetchListener - Variable in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- prefetchOnOpen - Variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Whether data blocks should be prefetched into the cache
- prefetchPathExclude - Static variable in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- PrefetchRunnable() - Constructor for class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner.PrefetchRunnable
-
- prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- prefix - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- prefix(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Adds this instance's identifier as a prefix to the passed str
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
-
- PREFIX_LENGTH_KEY - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
- PREFIX_LENGTH_KEY_DEPRECATED - Static variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- prefixes - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- PrefixFilter - Class in org.apache.hadoop.hbase.filter
-
Pass results that have same row prefix.
- PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
-
- PrefixKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Compress key by storing size of common prefix with previous KeyValue and storing raw size of
rest.
- PrefixKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- PrefixKeyDeltaEncoder.SeekerStateBufferedEncodedSeeker - Class in org.apache.hadoop.hbase.io.encoding
-
- prefixLength - Variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
Deprecated.
- prefixLength - Variable in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
-
- prefixLength - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- prefixLength - Variable in class org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
-
- prefixPathStr - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Prefix used when checking for wal membership.
- preflightChecks(MasterProcedureEnv, Boolean) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
Check that cluster is up and master is running.
- preflightChecks(MasterProcedureEnv, Boolean) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the memstore is flushed to disk.
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a Store's memstore is flushed to disk.
- preFlush(HStore, InternalScanner, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush
- preFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a memstore flush n
- preFlush(ObserverContext<RegionCoprocessorEnvironment>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for flush.
- preFlushScannerOpen(HStore, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before create StoreScanner for flush.
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This method is called before the flush is executed.
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- preFlushSeqIDEstimation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- preFlushSeqIDEstimation() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This method is called before the flush is executed.
- preGet(Get, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before get cluster status.
- preGetClusterMetrics() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetCounter - Variable in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
-
- preGetLocks(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getLocks request has been processed.
- preGetLocks() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetLocks(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getNamespaceDescriptor request has been processed.
- preGetNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics.ExampleRegionObserver
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client performs a Get
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preGetProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getProcedures request has been processed.
- preGetProcedures() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetProcedures(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before get the configured ReplicationPeerConfig for the specified peer n * @param peerId
a short name that identifies the peer
- preGetReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableDescriptors request has been processed.
- preGetTableDescriptors(List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<TableName>, List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetTableNames(ObserverContext<MasterCoprocessorEnvironment>, List<TableDescriptor>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a getTableNames request has been processed.
- preGetTableNames(List<TableDescriptor>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, String, TableName, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting user permissions.
- preGetUserPermissions(String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGetUserPermissions(User, String, String, TableName, byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before granting user permissions.
- preGrant(UserPermission, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preGrant(ObserverContext<MasterCoprocessorEnvironment>, UserPermission, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preGrantOrRevoke(User, String, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, List<Permission>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- preHasUserPermissions(String, List<Permission>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment>, String, List<Permission>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preHasUserPermissions(User, String, List<Permission>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before Increment.
- preIncrement(Increment, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preIncrement(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment>, Increment) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preIncrementAfterRowLock(Increment) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before getting if is rpc throttle enabled.
- preIsRpcThrottleEnabled() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preliminaries() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Corresponds to the "preliminaries" step of the original algorithm.
- preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before list decommissioned region servers.
- preListDecommissionedRegionServers() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment>, List<NamespaceDescriptor>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listNamespaceDescriptors request has been processed.
- preListNamespaceDescriptors(List<NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListNamespaces(ObserverContext<MasterCoprocessorEnvironment>, List<String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a listNamespaces request has been processed.
- preListNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before list replication peers.
- preListReplicationPeers(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before listSnapshots request has been processed.
- preListSnapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preListSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preLoadTableDescriptors - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before heartbeat to a lock.
- preLockHeartbeat(LockProcedure, boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preLogArchive(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL is going to be archived.
- preLogRoll(Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
The WAL is going to be rolled.
- preLogRoll(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- preLogRoll(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Call before the master initialization is set to true.
- preMasterInitialization() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- preMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the master local region memstore is flushed to disk.
- preMasterStoreFlush() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment>, Store) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before in memory compaction started.
- preMemStoreCompaction(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before in memory compaction.
- preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we do in memory compaction.
- preMemStoreCompactionCompact(HStore, InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before compacting memstore.
- preMemStoreCompactionCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preMemStoreCompactionCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before we open store scanner for in memory compaction.
- preMemStoreCompactionCompactScannerOpen(HStore) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before create StoreScanner for in memory compaction.
- preMergeRegions(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before merge regions request.
- preMergeRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Pre merge region action
- preMergeRegions(RegionInfo[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMergeRegions(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the regions merge.
- preMergeRegionsAction(RegionInfo[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before a merge
- preMergeRegionsCommit(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Post merge region action
- preMergeRegionsCommit(RegionInfo[], List<Mutation>, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked before merge regions operation writes the new region to hbase:meta
- preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called before update META step as part of regions merge transaction.
- preModify(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Action before modifying table.
- preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a family's store file tracker.
- preModifyColumnFamilyStoreFileTracker(TableName, byte[], String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[], String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor, NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a namespace's properties.
- preModifyNamespace(NamespaceDescriptor, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment>, NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTable(TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
- preModifyTable(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's properties.
- preModifyTableAction(TableName, TableDescriptor, TableDescriptor, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, TableDescriptor, TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to modifying a table's store file tracker.
- preModifyTableStoreFileTracker(TableName, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment>, TableName, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, ServerName, ServerName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to moving a given region from one region server to another.
- preMove(RegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMove(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preMoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are moved to target region server group
- preMoveServers(Set<Address>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are moved to target region server group
- preMoveServersAndTables(Set<Address>, Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preMoveTables(ObserverContext<MasterCoprocessorEnvironment>, Set<TableName>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before tables are moved to target region server group
- preMoveTables(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the region is reported as open to the master.
- preOpen() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Invoked before a region open.
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preOpen(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- prepare(ClientProtos.ScanResponse, int) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- prepare(RetryingCallable<?>) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- prepare(RetryingCallable<?>, int) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- prepare(RetryingCallable<?>) - Method in class org.apache.hadoop.hbase.client.NoOpRetryingInterceptorContext
-
- prepare(RetryingCallable<?>, int) - Method in class org.apache.hadoop.hbase.client.NoOpRetryingInterceptorContext
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- prepare(boolean) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Prepare by setting up any connections to servers, etc., ahead of call invocation.
- prepare(RetryingCallable<?>) - Method in class org.apache.hadoop.hbase.client.RetryingCallerInterceptorContext
-
This prepares the context object by populating it with information specific to the
implementation of the
RetryingCallerInterceptor
along with which this will be used.
- prepare(RetryingCallable<?>, int) - Method in class org.apache.hadoop.hbase.client.RetryingCallerInterceptorContext
-
Telescopic extension that takes which of the many retries we are currently in.
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable
-
Two responsibilities - if the call is already completed (by another replica) stops the
retries.
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- prepare(E) - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- prepare() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event handlers should do all the necessary checks in this method (rather than in the
constructor, or in process()) so that the caller, which is mostly executed in the ipc context
can fail fast.
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
Called once per LB invocation to give the cost function to initialize it's state, and perform
any costly calculation.
- prepare(int) - Method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
Called once per LB invocation to give the cost function to initialize it's state, and perform
any costly calculation.
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.MoveCostFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- prepare(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.TableSkewCostFunction
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- prepare() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
This is not thread safe.
- prepare(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
Reset the map if it is different with the last Cell.
- prepare() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Prepare for a store flush (create snapshot) Requires pausing writes.
- prepare(T) - Method in class org.apache.hadoop.hbase.zookeeper.InstancePending
-
- prepare(Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.PendingWatcher
-
Associates the substantial watcher of processing events.
- prepareBulkLoad(Connection) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- prepareBulkLoad(RpcController, ClientProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- prepareBulkLoad(byte[], String, boolean, String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
-
Called before an HFile is actually loaded
- prepareBulkLoad(RpcController, ClientProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- prepareBulkLoad(HRegion, ClientProtos.PrepareBulkLoadRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- prepareBulkLoad(byte[], String, boolean, String) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- prepareClone(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
Action before any real action of cloning from snapshot.
- prepareCreate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
Action before any real action of creating namespace.
- prepareCreate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- prepareDecoding(int, int, ByteBuff, ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
-
Perform all actions that need to be done before the encoder's real decoding process.
- prepareDecoding(int, int, ByteBuff, ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- prepareDelete(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
Action before any real action of deleting namespace.
- prepareDelete(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- prepareDelete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Prepare a delete for a row mutation processor
- prepareDeleteTimestamps(Mutation, Map<byte[], List<Cell>>, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Set up correct timestamps in the KVs in Delete object.
- prepareDisable(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Action before any real action of disabling table.
- prepareEnable(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Action before any real action of enabling table.
- prepareEncoding(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
prepare to start a new encoding.
- prepareFlushResult - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Saved state from replaying prepare flush cache
- PrepareFlushResult(HRegion.FlushResultImpl, long) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
Constructs an early exit case
- PrepareFlushResult(TreeMap<byte[], StoreFlushContext>, TreeMap<byte[], List<Path>>, TreeMap<byte[], MemStoreSize>, long, long, long, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
Constructs a successful prepare flush result
- PrepareFlushResult(HRegion.FlushResultImpl, TreeMap<byte[], StoreFlushContext>, TreeMap<byte[], List<Path>>, TreeMap<byte[], MemStoreSize>, long, long, long, MemStoreSizing) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- prepareForBlockReader(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Prepares the streams for block reader.
- prepareGet(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- prepareHFileQueue(Path, Table, Deque<LoadIncrementalHFiles.LoadQueueItem>, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Prepare a collection of
LoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the
passed directory and validates whether the prepared queue has all the valid table column
families in it.
- prepareHFileQueue(Path, Table, Deque<LoadIncrementalHFiles.LoadQueueItem>, boolean, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Prepare a collection of
LoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the
passed directory and validates whether the prepared queue has all the valid table column
families in it.
- prepareHFileQueue(Map<byte[], List<Path>>, Table, Deque<LoadIncrementalHFiles.LoadQueueItem>, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Prepare a collection of
LoadIncrementalHFiles.LoadQueueItem
from list of source hfiles contained in the
passed directory and validates whether the prepared queue has all the valid table column
families in it.
- prepareMergeRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Prepare merge and do some check
- prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, long, List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
If necessary, calls preBatchMutate() CP hook for a mini-batch and updates metrics, cell
count, tags and timestamp for all cells of all operations in a mini-batch.
- prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, long, List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation>, long, List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- prepareModify(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
Action before any real action of adding namespace.
- prepareModify(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Check conditions before any real action of modifying a table.
- prepareProcedure(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- preparePutToStoreMap - Variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- prepareRestore(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Action before any real action of restoring from snapshot.
- prepareSplitRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Prepare to Split region.
- prepareTableToReopenRegionsMap(Map<TableName, List<byte[]>>, byte[], int) - Method in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
- prepareTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Prepare the new task
- prepareTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- prepareToTakeSnapshot(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check to make sure that we are OK to run the passed snapshot.
- prepareTruncate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- prepareWriterFor(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- prepareZKMulti(Iterable<Op>) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Convert Iterable of Op
we got into the ZooKeeper.Op instances to
actually pass to multi (need to do this in order to appendMetaData).
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.DisablePeerProcedure
-
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.EnablePeerProcedure
-
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
Called before we start the actual processing.
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- prePeerModification(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- prepend(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Prepend a node to the tree
- prepend(TNode, TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Prepend a node to the tree before a specific node
- prependCombined(Result[], int) - Method in class org.apache.hadoop.hbase.client.CompleteScanResultCache
-
- prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
-
Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call.
- prePrepareBulkLoad(User) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Authorization check for SecureBulkLoadProtocol.prepareBulkLoad()
- prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- prePrepareTimeStampForDeleteVersion(Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment>, Mutation, Cell, byte[], Get) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preProcess(HRegion, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- preProcess(RowProcessor<?, ?>, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- preProcess(HRegion, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
The hook to be executed before process().
- preprocessMask(byte[]) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
We need to preprocess mask array, as since we treat 2's as unfixed positions and -1 (0xff) as
fixed positions n * @return mask array
- preprocessSearchKey(Pair<byte[], byte[]>) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client stores a value.
- prePut(Put, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment>, ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before recommission region server.
- preRecommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment>, ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to marking a given region as offline.
- preRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRegionOffline(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRegistrationInitialization() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
All initialization needed before we go register with Master.
Do bare minimum.
- preRemovePeer(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- preRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before remove a replication peer n * @param peerId a short name that identifies the peer
- preRemoveReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a region server group is removed
- preRemoveRSGroup(String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRemoveServers(ObserverContext<MasterCoprocessorEnvironment>, Set<Address>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before servers are removed from rsgroup
- preRemoveServers(Set<Address>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment>, String, String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before rename rsgroup.
- preRenameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before replaying WALs for this region.
- preReplayWALs(RegionInfo, Path) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
- preReplicateLogEntries() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRequestLock(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, RegionInfo[], String) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before new LockProcedure is queued.
- preRequestLock(String, TableName, RegionInfo[], LockType, String) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRequestLock(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, RegionInfo[], String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a snapshot is restored.
- preRestoreSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before revoking user permissions.
- preRevoke(UserPermission) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preRevoke(ObserverContext<MasterCoprocessorEnvironment>, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
This will be called before executing user request to roll a region server WAL.
- preRollWALWriterRequest() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preRunCleaner() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client closes a scanner.
- preScannerClose(InternalScanner) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Supports Coprocessor 'bypass'.
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerClose(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client asks for the next row on a scanner.
- preScannerNext(InternalScanner, List<Result>, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerNext(ObserverContext<RegionCoprocessorEnvironment>, InternalScanner, List<Result>, int, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.ScanModifyingObserver
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before the client opens a new scanner.
- preScannerOpen(Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- preSelect(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Called before coprocessor preCompactSelection and should filter the candidates for coprocessor;
i.e.
- preSelect(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine.DateTieredCompactionContext
-
- preSelect(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine.DefaultCompactionContext
-
- preSelect(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine.StripeCompaction
-
- preSelectCompactionForCoprocessor(Collection<HStoreFile>, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- preSelectFilesForCoprocessor(StripeCompactionPolicy.StripeInformationProvider, List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- preserveAttributes(Path, FileStatus) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
Try to Preserve the files attribute selected by the user copying them from the source file
This is only required when you are exporting as a different user than "hbase" or on a system
that doesn't have the "hbase" user.
- preserveSplits - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.TruncateTableFuture
-
- preserveSplits - Variable in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the namespace is stored.
- preSetNamespaceQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the region server is stored.
- preSetRegionServerQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to setting split / merge switch Supports Coprocessor 'bypass'.
- preSetSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment>, boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the table is stored.
- preSetTableQuota(TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment>, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified table is stored.
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, GlobalQuotaSettings) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the quota for the user on the specified namespace is stored.
- preSetUserQuota(String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(String, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(String, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, TableName, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment>, String, String, GlobalQuotaSettings) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to shutting down the full HBase cluster, including this
HMaster
process.
- preShutdown() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preShutdown(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before a new snapshot is taken.
- preSnapshot(SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSnapshot(ObserverContext<MasterCoprocessorEnvironment>, SnapshotDescription, TableDescriptor) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSnapshotOperation() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Sets the store up for a region level snapshot operation.
- preSplitAfterMETAAction(User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
This will be called after update META step as part of split table region procedure.
- preSplitBeforeMETAAction(byte[], List<Mutation>, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
This will be called before update META step as part of split table region procedure.
- preSplitRegion(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the split region procedure is called.
- preSplitRegion(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Action before splitting region in a table.
- preSplitRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before calling the split region procedure
- preSplitRegion(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment>, TableName, byte[]) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the region is split.
- preSplitRegionAction(TableName, byte[], User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
Invoked just before a split
- preSplitRegionAfterMETA(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Pre split region actions after the Point-of-No-Return step
- preSplitRegionAfterMETAAction(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called after update META step as part of split transaction
- preSplitRegionBeforeMETA(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Post split region actions before the Point-of-No-Return step
- preSplitRegionBeforeMETAAction(ObserverContext<MasterCoprocessorEnvironment>, byte[], List<Mutation>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
This will be called before update META step as part of split transaction.
- PressureAwareCompactionThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
-
- PressureAwareCompactionThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
-
- PressureAwareFlushThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
-
- PressureAwareFlushThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
-
- PressureAwareThroughputController - Class in org.apache.hadoop.hbase.regionserver.throttle
-
- PressureAwareThroughputController() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- PressureAwareThroughputController.ActiveOperation - Class in org.apache.hadoop.hbase.regionserver.throttle
-
Stores the information of one controlled compaction.
- preStop(String, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called immediately prior to stopping this
HMaster
process.
- preStopMaster() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preStopMaster(ObserverContext<MasterCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerObserver
-
Called before stopping region server.
- preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment>, FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, StoreFileReader) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
- preStoreFileReaderOpen(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preStoreFileReaderOpen(ReaderContext, CacheConfig) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in class org.apache.hadoop.hbase.coprocessor.example.WriteHeavyIncrementObserver
-
- preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, ScanOptions) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a store opens a new scanner.
- preStoreScannerOpen(HStore, Scan) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Called before open store scanner for user scan.
- preSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before switching exceed throttle quota state.
- preSwitchExceedThrottleQuota(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before switching rpc throttle enabled state.
- preSwitchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before the table memstore is flushed to disk.
- preTableFlush(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preTableFlush(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preTransitCheck(RegionStateNode, RegionState.State[]) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- preTruncate(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
truncates a table.
- preTruncateTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preTruncateTable(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment>, TableName) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before
HMaster
truncates a table.
- preTruncateTableAction(TableName, User) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- prettyPrint(String) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
-
Use logging.
- prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- PrettyPrinter - Class in org.apache.hadoop.hbase.util
-
- PrettyPrinter() - Constructor for class org.apache.hadoop.hbase.util.PrettyPrinter
-
- PrettyPrinter.Unit - Enum in org.apache.hadoop.hbase.util
-
- prettyPrintJournal() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- prettyPrintJournal() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called prior to unassigning a given region.
- preUnassign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preUnassign(ObserverContext<MasterCoprocessorEnvironment>, RegionInfo) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preUpdate(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
Issue any synchronization and test needed before applying the update
- preUpdate(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
Issue any synchronization and test needed before applying the update For compacting memstore
this means checking the update can increase the size without overflow
- preUpdate(MutableSegment, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- preUpdatePeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
Return the old peer description.
- preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before update peerConfig for the specified peer n * @param peerId a short name that
identifies the peer
- preUpdateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment>, String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- preUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment>, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.coprocessor.MasterObserver
-
Called before update rsgroup config.
- preUpdateRSGroupConfig(String, Map<String, String>) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- PreUpgradeValidator - Class in org.apache.hadoop.hbase.tool
-
Tool for validating that cluster can be upgraded from HBase 1.x to 2.0
- PreUpgradeValidator() - Constructor for class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- prev - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.Node
-
- PREV_BLOCK_OFFSET_INDEX - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Header
-
- prevBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
The offset of the previous block on disk.
- prevBlockOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
-
- prevBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- prevCell - Variable in class org.apache.hadoop.hbase.io.encoding.EncodingState
-
The previous Cell the encoder encoded.
- prevCell - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
The prev Cell that was processed
- prevCell - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- prevCell - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- prevCellList - Variable in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
- prevChunk - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
Previous chunk, so that we can create another similar chunk
- prevFam - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- prevFilterRCList - Variable in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
Save previous return code and previous cell for every filter in filter list.
- previous - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- previous - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- previous - Variable in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
RegionInfo from previous row.
- previousAverage - Variable in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
-
- previousFilteredReadRequestCount - Variable in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- previousKey(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Decrement the timestamp.
- previousLastReportTimestamp - Variable in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- previousLogTime - Static variable in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- previousReadRequestCount - Variable in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- previousState - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Ordinal of the previous state.
- previousWriteRequestCount - Variable in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- prevMaxStoreFileRefCount - Variable in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- prevOffset - Variable in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- prevOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
The offset of the previous block of the same type
- prevOffsetByType - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Offset of previous block by block type.
- prevQual - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- prevRegionsRecoveryInterval - Variable in class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- prevRSGroups - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- prevTime - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- prevTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFile
-
- prevTimestampAndType - Variable in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- prevTimestampOffset - Variable in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffCompressionState
-
- prevTuneDirection - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- preWALAppend(ObserverContext<RegionCoprocessorEnvironment>, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called just before the WAL Entry is appended to the WAL.
- preWALAppend(WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.RegionObserver
-
Called before a
WALEdit
replayed for this region.
- preWALRestore(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- preWALRoll(ObserverContext<? extends WALCoprocessorEnvironment>, Path, Path) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
Called before rolling the current WAL
- preWALRoll(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Called before rolling the current WAL
- preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment>, RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.coprocessor.WALObserver
-
- preWALWrite(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- PRIMARY_CALL_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- PRIMARY_CALL_TIMEOUT_MICROSECOND - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- PRIMARY_CALL_TIMEOUT_MICROSECOND_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- PRIMARY_REGION_COUNT_SKEW_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- PRIMARY_SCAN_TIMEOUT_MICROSECOND - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- PRIMARY_SCAN_TIMEOUT_MICROSECOND_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- primaryCallTimeoutMicroSecond - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- primaryCallTimeoutMicroseconds - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- primaryCallTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- primaryEvictedBlockCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
The total number of blocks for primary replica that have been evicted
- primaryHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
The number of getBlock requests that were cache hits from primary replica
- primaryHRIForDeployedReplica - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- primaryMetaScanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- primaryMissCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
The number of getBlock requests for primary replica that were cache misses
- primaryOperationTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- PrimaryRegionCountSkewCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Compute the cost of a potential cluster state from skew in number of primary regions on a
cluster.
- PrimaryRegionCountSkewCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- primaryReplica - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- primaryReplicaReader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- primaryReplicaReader - Variable in class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- primaryReplicaReader - Variable in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
-
- primaryRSToRegionMap - Variable in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- primaryRSToRegionMap - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- primaryScanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- PRIME - Static variable in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- PRIME - Static variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- primeInRow(int) - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Find a primed zero in the specified row.
- principal - Variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient.KerberosConfiguration
-
- principal - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- principal - Variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet.RemoteUserIdentity
-
- principal - Variable in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication.JaasConfiguration
-
- print(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
-
- print(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- print(String) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(Object) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(char) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(short) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(long) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(float) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(double) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- print(boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- print(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- print(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- print(Object) - Static method in class org.apache.hadoop.hbase.util.JRubyFormat
-
- printAssignmentPlan(FavoredNodesPlan) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Print the assignment plan to the system output stream n
- printBlockHeaders - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printBlockIndex - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printCell(Cell) - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- printCell(PrintStream, Map<String, Object>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- printChoreDetails(String, ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Prints a summary of important details about the chore.
- printChoreServiceDetails(String) - Method in class org.apache.hadoop.hbase.ChoreService
-
Prints a summary of important details about the service.
- printDispersionScores(TableName, SnapshotOfRegionAssignmentFromMeta, int, FavoredNodesPlan, boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- printEntry(ProcedureProtos.ProcedureWALEntry) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- printFiles(boolean, boolean) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Collect the hfiles and logs statistics of the snapshot and dump the file list if requested and
the collected information.
- printFormat(String, Object...) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- printHeader(ProcedureProtos.ProcedureWALHeader) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- printHelp(Options) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- printHelp() - Static method in class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
- printHistogram(Histogram) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter
-
- printHServerAddressSet(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- printInfo() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- PrintingErrorReporter() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- printKey - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printLocalityAndDispersionForCurrentPlan(Map<String, Map<String, Float>>) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- printMeta(HFile.Reader, Map<byte[], byte[]>) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printProcedure(Procedure<?>) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- printRow(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- printRow(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- printRow(TRowResult) - Static method in class org.apache.hadoop.hbase.util.ClientUtils
-
copy values into a TreeMap to get them in sorted order and print it
- printSchema() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- printSizeInBytes - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- printStackTrace(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
- printStatistics() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
Prints the statistics.
- printStats - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printStats(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication.ReplicationStatisticsTask
-
- printStats(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl.ReplicationStatisticsChore
-
- printTableSummary(SortedMap<TableName, HbckTableInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Prints summary of all tables found on the system.
- printThreadInfo(PrintStream, String) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
Print all of the thread's information and stack traces.
- printThreadInfo(PrintStream, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Print all of the thread's information and stack traces.
- printUsage(Options) - Method in class org.apache.hadoop.hbase.hbtop.HBTop
-
- printUsage() - Static method in class org.apache.hadoop.hbase.http.log.LogLevel
-
- printUsage() - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- printUsage(int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Prints usage without error message.
- printUsage() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- printUsage() - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
-
- printUsage() - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
- printUsage() - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- printUsage(String) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- printUsage() - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- printUsage(String) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- printUsage(String, String) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- printUsage() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- printUsage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- printUsage() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- printUsage() - Method in class org.apache.hadoop.hbase.tool.DataBlockEncodingValidator
-
- printUsage() - Method in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- printUsage() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- printUsage(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- printUsage(Options) - Static method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- printUsageAndExit() - Static method in class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- printUsageAndExit(String, int) - Static method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- printUsageAndExit(Options, int) - Static method in class org.apache.hadoop.hbase.rest.RESTServer
-
- printUsageAndExit(Options, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- printUsageAndExit(Options, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
-
- printValue - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- printVersions(ByteBuffer, List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- priority - Variable in class org.apache.hadoop.hbase.client.Action
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- priority(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- priority(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- priority(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- priority(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- priority - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- priority - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- priority - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- PRIORITY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- priority - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Chaining priority
- PRIORITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- priority - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- priority - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- priority - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- priority - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
Priority to set on this request.
- priority - Variable in class org.apache.hadoop.hbase.ipc.PluggableBlockingQueue
-
- priority - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor.CallPriorityComparator
-
- priority - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- priority - Variable in class org.apache.hadoop.hbase.master.procedure.Queue
-
- priority - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- priority - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.TableCoprocessorAttribute
-
- priority - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- PRIORITY_HIGHEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Highest installation priority
- PRIORITY_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- PRIORITY_KEY - Static variable in class org.apache.hadoop.hbase.constraint.Constraints
-
- PRIORITY_LOWEST - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Lowest installation priority
- PRIORITY_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- PRIORITY_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- PRIORITY_SYSTEM - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
High (system) installation priority
- PRIORITY_UNSET - Static variable in class org.apache.hadoop.hbase.HConstants
-
QOS attributes: these attributes are used to demarcate RPC call processing by different set of
handlers.
- PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
Default installation priority for user coprocessors
- PRIORITY_USER - Static variable in interface org.apache.hadoop.hbase.regionserver.Store
-
The default priority for user-specified compaction requests.
- priorityExecutor - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- PriorityFunction - Interface in org.apache.hadoop.hbase.ipc
-
Function to figure priority of incoming request.
- PriorityQueue(int, Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- PrivateCellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful slinging
Cell
instances.
- PrivateCellUtil() - Constructor for class org.apache.hadoop.hbase.PrivateCellUtil
-
Private constructor to keep this class from being instantiated.
- PrivateCellUtil.EmptyByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
These cells are used in reseeks/seeks to improve the read performance.
- PrivateCellUtil.EmptyCell - Class in org.apache.hadoop.hbase
-
These cells are used in reseeks/seeks to improve the read performance.
- PrivateCellUtil.FirstOnRowByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowColByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowColCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowColTSCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.FirstOnRowDeleteFamilyCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.LastOnRowByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.LastOnRowCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.LastOnRowColByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.LastOnRowColCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.TagRewriteByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.TagRewriteCell - Class in org.apache.hadoop.hbase
-
This can be used when a Cell has to change with addition/removal of one or more tags.
- PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell - Class in org.apache.hadoop.hbase
-
- PrivateCellUtil.ValueAndTagRewriteCell - Class in org.apache.hadoop.hbase
-
- proc - Variable in class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- proc - Variable in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- proc - Variable in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree.Entry
-
- proc - Variable in class org.apache.hadoop.hbase.procedure2.store.ProtoAndProcedure
-
- PROC_FAMILY - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- PROC_QUALIFIER - Static variable in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- procedure - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- Procedure - Class in org.apache.hadoop.hbase.procedure
-
A globally-barriered distributed procedure.
- Procedure(ProcedureCoordinator, ForeignExceptionDispatcher, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
-
Creates a procedure.
- Procedure(ProcedureCoordinator, long, long, String, byte[], List<String>) - Constructor for class org.apache.hadoop.hbase.procedure.Procedure
-
Create a procedure.
- procedure - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- Procedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Base Procedure class responsible for Procedure Metadata; e.g.
- Procedure() - Constructor for class org.apache.hadoop.hbase.procedure2.Procedure
-
- Procedure.LockState - Enum in org.apache.hadoop.hbase.procedure2
-
- PROCEDURE_RETRY_MAX_SLEEP_TIME_MS - Static variable in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- PROCEDURE_RETRY_SLEEP_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- ProcedureAbortedException - Exception in org.apache.hadoop.hbase.procedure2
-
Thrown when a procedure is aborted
- ProcedureAbortedException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureAbortedException
-
default constructor
- ProcedureAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureAbortedException
-
Constructor
- procedureAdded(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
-
- ProcedureBiConsumer() - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ProcedureBiConsumer
-
- procedureCall(PREQ, RawAsyncHBaseAdmin.MasterRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<Long, PRESP>, RawAsyncHBaseAdmin.ProcedureBiConsumer) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- procedureCall(TableName, PREQ, RawAsyncHBaseAdmin.MasterRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<Long, PRESP>, RawAsyncHBaseAdmin.ProcedureBiConsumer) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- procedureCall(Consumer<AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<?>>, PREQ, RawAsyncHBaseAdmin.MasterRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<Long, PRESP>, RawAsyncHBaseAdmin.ProcedureBiConsumer) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- ProcedureCoordinator - Class in org.apache.hadoop.hbase.procedure
-
This is the master side of a distributed complex procedure execution.
- ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Create and start a ProcedureCoordinator.
- ProcedureCoordinator(ProcedureCoordinatorRpcs, ThreadPoolExecutor, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Create and start a ProcedureCoordinator.
- ProcedureCoordinatorRpcs - Interface in org.apache.hadoop.hbase.procedure
-
RPCs for the coordinator to run a barriered procedure with subprocedures executed at distributed
members.
- ProcedureDeque - Class in org.apache.hadoop.hbase.procedure2
-
Type class.
- ProcedureDeque() - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureDeque
-
- ProcedureDescriber - Class in org.apache.hadoop.hbase.master.procedure
-
- ProcedureDescriber() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedureDescriber
-
- procedureEnv - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- ProcedureEvent<T> - Class in org.apache.hadoop.hbase.procedure2
-
Basic ProcedureEvent that contains an "object", which can be a description or a reference to the
resource to wait on, and a queue for suspended procedures.
- ProcedureEvent(T) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
- ProcedureException - Exception in org.apache.hadoop.hbase.procedure2
-
- ProcedureException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
-
default constructor
- ProcedureException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
-
Constructor
- ProcedureException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureException
-
- procedureExecutor - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- procedureExecutor - Variable in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- ProcedureExecutor<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Thread Pool that executes the submitted procedures.
- ProcedureExecutor(Configuration, TEnvironment, ProcedureStore) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- ProcedureExecutor(Configuration, TEnvironment, ProcedureStore, ProcedureScheduler) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- ProcedureExecutor.KeepAliveWorkerThread - Class in org.apache.hadoop.hbase.procedure2
-
- ProcedureExecutor.ProcedureExecutorListener - Interface in org.apache.hadoop.hbase.procedure2
-
- ProcedureExecutor.Testing - Class in org.apache.hadoop.hbase.procedure2
-
Class with parameters describing how to fail/die when in testing-context.
- ProcedureExecutor.WorkerMonitor - Class in org.apache.hadoop.hbase.procedure2
-
- ProcedureExecutor.WorkerThread - Class in org.apache.hadoop.hbase.procedure2
-
- procedureFinished(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
-
- procedureFinished(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- ProcedureFuture(HBaseAdmin, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- ProcedureFuture(ProcedureExecutor<MasterProcedureEnv>, Procedure<?>) - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- ProcedureInMemoryChore<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Special procedure used as a chore.
- ProcedureInMemoryChore(int) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
-
- procedureLoaded(long) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureExecutor.ProcedureExecutorListener
-
- ProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
- ProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManager
-
- ProcedureManagerHost<E extends ProcedureManager> - Class in org.apache.hadoop.hbase.procedure
-
Provides the common setup framework and runtime services for globally barriered procedure
invocation from HBase services.
- ProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- procedureMap - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- ProcedureMember - Class in org.apache.hadoop.hbase.procedure
-
Process to kick off and manage a running
Subprocedure
on a member.
- ProcedureMember(ProcedureMemberRpcs, ThreadPoolExecutor, SubprocedureFactory) - Constructor for class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Instantiate a new ProcedureMember.
- ProcedureMemberRpcs - Interface in org.apache.hadoop.hbase.procedure
-
This is the notification interface for Procedures that encapsulates message passing from members
to a coordinator.
- ProcedureMetrics - Interface in org.apache.hadoop.hbase.procedure2
-
With this interface, the procedure framework provides means to collect following set of metrics
per procedure type for all procedures:
Count of submitted procedure instances
Time histogram for successfully completed procedure instances
Count of failed procedure instances
Please implement this interface to return appropriate metrics.
- procedureMgrMap - Variable in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- ProcedurePrepareLatch - Class in org.apache.hadoop.hbase.master.procedure
-
Latch used by the Master to have the prepare() sync behaviour for old clients, that can only get
exceptions in a synchronous way.
- ProcedurePrepareLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- ProcedurePrepareLatch.CompatibilityLatch - Class in org.apache.hadoop.hbase.master.procedure
-
- ProcedurePrepareLatch.NoopLatch - Class in org.apache.hadoop.hbase.master.procedure
-
- procedureResultReporter - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- procedureRetriever - Variable in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- procedureRetriever - Variable in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- procedures - Variable in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- procedures - Variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- procedures - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Helper map to lookup the live procedures by ID.
- ProcedureScheduler - Interface in org.apache.hadoop.hbase.procedure2
-
Keep track of the runnable procedures
- ProcedureSpanBuilder - Class in org.apache.hadoop.hbase.procedure2.trace
-
Construct a
Span
instance for a
Procedure
execution.
- ProcedureSpanBuilder(Procedure<?>) - Constructor for class org.apache.hadoop.hbase.procedure2.trace.ProcedureSpanBuilder
-
- ProcedureStateSerializer - Interface in org.apache.hadoop.hbase.procedure2
-
- procedureStore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ProcedureStore - Interface in org.apache.hadoop.hbase.procedure2.store
-
The ProcedureStore is used by the executor to persist the state of each procedure execution.
- ProcedureStore.ProcedureIterator - Interface in org.apache.hadoop.hbase.procedure2.store
-
An Iterator over a collection of Procedure
- ProcedureStore.ProcedureLoader - Interface in org.apache.hadoop.hbase.procedure2.store
-
Interface passed to the ProcedureStore.load() method to handle the store-load events.
- ProcedureStore.ProcedureStoreListener - Interface in org.apache.hadoop.hbase.procedure2.store
-
Store listener interface.
- ProcedureStoreBase - Class in org.apache.hadoop.hbase.procedure2.store
-
- ProcedureStoreBase() - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- ProcedureStoreTracker - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
- ProcedureStoreTracker() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- ProcedureStoreTracker.DeleteState - Enum in org.apache.hadoop.hbase.procedure2.store.wal
-
Deprecated.
- ProcedureSuspendedException - Exception in org.apache.hadoop.hbase.procedure2
-
- ProcedureSuspendedException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureSuspendedException
-
default constructor
- ProcedureSuspendedException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureSuspendedException
-
Constructor
- ProcedureSyncWait - Class in org.apache.hadoop.hbase.master.procedure
-
Helper to synchronously wait on conditions.
- ProcedureSyncWait() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- ProcedureSyncWait.Predicate<T> - Interface in org.apache.hadoop.hbase.master.procedure
-
- ProcedureSyncWait.ProcedureFuture - Class in org.apache.hadoop.hbase.master.procedure
-
- ProcedureTree - Class in org.apache.hadoop.hbase.procedure2.store
-
Used to build the tree for procedures.
- ProcedureTree(Map<Long, ProcedureTree.Entry>) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- ProcedureTree.Entry - Class in org.apache.hadoop.hbase.procedure2.store
-
- procedureType - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
- ProcedureUtil - Class in org.apache.hadoop.hbase.procedure2
-
Helper to convert to/from ProcedureProtos
- ProcedureUtil() - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- ProcedureUtil.CompatStateSerializer - Class in org.apache.hadoop.hbase.procedure2
-
A serializer (deserializer) for those Procedures which were serialized before this patch.
- ProcedureUtil.StateSerializer - Class in org.apache.hadoop.hbase.procedure2
-
A serializer for our Procedures.
- ProcedureWALFile - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
- ProcedureWALFile(FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- ProcedureWALFile(FileSystem, Path, ProcedureProtos.ProcedureWALHeader, long, long) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- ProcedureWALFormat - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
- ProcedureWALFormat() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
Deprecated.
- ProcedureWALFormat.InvalidWALDataException - Exception in org.apache.hadoop.hbase.procedure2.store.wal
-
Deprecated.
- ProcedureWALFormat.Loader - Interface in org.apache.hadoop.hbase.procedure2.store.wal
-
Deprecated.
- ProcedureWALFormatReader - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
- ProcedureWALFormatReader(ProcedureStoreTracker, ProcedureWALFormat.Loader) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- ProcedureWALPrettyPrinter - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
- ProcedureWALPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- ProcedureYieldException - Exception in org.apache.hadoop.hbase.procedure2
-
- ProcedureYieldException() - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureYieldException
-
default constructor
- ProcedureYieldException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.ProcedureYieldException
-
Constructor
- PROCEED - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- proceed() - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Called by the filter after it decides that the request may proceed.
- proceed() - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
- proceedWithMergePlanning(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- proceedWithSplitPlanning(TableDescriptor) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- process(RpcController, RowProcessorProtos.ProcessRequest, RpcCallback<RowProcessorProtos.ProcessResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
Pass a processor to region to process multiple rows atomically.
- process() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
This method is the main processing loop to be implemented by the various subclasses.
- process(String) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
Configures the client to send HTTP request to the URL.
- process(Logger, String, PrintWriter) - Static method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- process - Variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- process(ByteBuf) - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- process(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- process(ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
-
- process() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
Process the data buffer and clean the connection state for the next call.
- process() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Execute the core common portions of taking a snapshot.
- process() - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.RSProcedureHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- process() - Method in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- process(long, HRegion, List<Mutation>, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
HRegion handles the locks and MVCC and invokes this method properly.
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
-
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.PendingWatcher
-
- process(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Method called from ZooKeeper for events and connection status.
- PROCESS_CALL_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- PROCESS_CALL_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- processAllResponses(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
Process all the responses for this connection
- processANDorOROp(Operator, Stack<ExpressionNode>, String, int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- processAsActiveMaster(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- processAssignmentPlans(HashMap<RegionInfo, RegionStateNode>, HashMap<RegionInfo, ServerName>, List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- processAssignQueue() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- processBatchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Process a mixed batch of Get, Put and Delete actions.
- processBatchCallback(List<? extends Row>, TableName, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
Randomly pick a connection and process the batch of actions for a given table
- processCallTime - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- processCloseParan(Stack<ExpressionNode>, String, int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- processConnectionHeader(ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- processed - Variable in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- processedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- processedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- processedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- processedWildcardMask - Variable in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- processEvent(WatchedEvent) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- processException(Throwable) - Method in class org.apache.hadoop.hbase.rest.ResourceBase
-
- processFile(Path, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- processFile(Path) - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
Reads a log file and outputs its contents.
- processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
reads a log file and outputs its contents, one transaction at a time, as specified by the
currently configured options n * the HBase configuration relevant to this log file n * the path
of the log file to be read n * may be unable to access the configured filesystem or requested
file.
- processFileArchivals(RegionServerStatusProtos.FileArchiveNotificationRequest, Connection, Configuration, FileSystem) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- processFirstDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- processFirstDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- processing(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Add sn<
to set of processing deadservers.
- processingList - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- processingProcs - Variable in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- processingServers - Variable in class org.apache.hadoop.hbase.master.DeadServer
-
Set of dead servers currently being processed by a SCP.
- processingTime - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- processingTime - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- processKV(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, Put, Delete) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- processLabelExpNode(LeafExpressionNode, Stack<ExpressionNode>, String, int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- processMetaRecord(Result) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- processNamespacesWithQuotas(Set<String>, Multimap<String, TableName>) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Processes each namespace which has a quota defined and moves all of the tables contained in
that namespace into or out of violation of the quota.
- processNewCandidateStripes(TreeMap<byte[], HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- processNOTOp(Stack<ExpressionNode>, String, int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- processOfflineRegions() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create assign procedure for offline regions.
- processOldArgs(List<String>) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- processOldArgs(List<String>) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
For backward compatibility.
- processOneRpc(ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- processOpenParan(Stack<ExpressionNode>, String, int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.procedure2.store.region.WALProcedurePrettyPrinter
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- processOptions(String[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Parse the command line options to set parameters the conf.
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.tool.DataBlockEncodingValidator
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.tool.HFileContentValidator
-
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
This method is called to process the options after they have been parsed.
- processOptions(CommandLine) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- processor - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- processParameter(String, String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- processParameters(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- processPreamble(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- processProcedureWALFile(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
- processRegionServers(Collection<ServerName>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Contacts each regionserver and fetches metadata about regions.
- processRequest(ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
n * Has the request header and the request param and optionally encoded data buffer all in this
one array.
- processResponse(SimpleServerRpcConnection, RpcResponse) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
Process the response for this call.
- processResponseForConnectionHeader() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
-
- processResult(int, String, Object, String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
-
- processResult(int, String, Object) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
-
- processResult(int, String, Object, byte[], Stat) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.GetDataAsyncCallback
-
- processResult(int, String, Object, byte[], Stat) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.GetDataAsyncCallback
-
- processResults() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
Process new files, and add them either to the structure of existing stripes, or to the list
of new candidate stripes.
- processRowsWithLocks(RowProcessor<?, ?>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- processRowsWithLocks(RowProcessor<?, ?>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- processRowsWithLocks(RowProcessor<?, ?>, long, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- processSequentially(ZKWatcher, List<ZKUtil.ZKUtilOp>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- processTablesWithQuotas(Set<TableName>) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Processes each TableName
which has a quota defined and moves it in or out of violation
based on the space use.
- processTasks(Iterable<TaskMonitor.TaskAndWeakRefPair>, TaskMonitor.TaskFilter, List<MonitoredTask>) - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- processTime - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor.PacketAckData
-
- processUnwrappedData(byte[]) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- processUpdate(NamespacesInstanceModel, boolean, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
- ProcessUtils - Class in org.apache.hadoop.hbase.util
-
Process related utilities.
- ProcessUtils() - Constructor for class org.apache.hadoop.hbase.util.ProcessUtils
-
- processWriteBlockResponse(Channel, DatanodeInfo, Promise<Channel>, int) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- procExec - Variable in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- procExecutionLock - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- procExecutionLock - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- procId - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- procId - Variable in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- procId - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- procId - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOperation
-
- procId - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ServerOperation
-
- procId - Variable in exception org.apache.hadoop.hbase.master.procedure.ServerCrashException
-
- procId - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- procId - Variable in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
-
- procId - Variable in class org.apache.hadoop.hbase.procedure2.trace.ProcedureSpanBuilder
-
- procId - Variable in class org.apache.hadoop.hbase.regionserver.handler.RSProcedureHandler
-
- procIds - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- procMap - Variable in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- procMap - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- procName - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- procName - Variable in class org.apache.hadoop.hbase.procedure2.FailedProcedure
-
- procResultFound - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- procs - Variable in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- procSched - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- procSize - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotRecordReader
-
- producer - Variable in class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
-
- ProfileOutputServlet - Class in org.apache.hadoop.hbase.http
-
- ProfileOutputServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileOutputServlet
-
- PROFILER_SCRIPT - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- profilerLock - Variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- ProfileServlet - Class in org.apache.hadoop.hbase.http
-
Servlet that runs async-profiler as web-endpoint.
- ProfileServlet() - Constructor for class org.apache.hadoop.hbase.http.ProfileServlet
-
- ProfileServlet.DisabledServlet - Class in org.apache.hadoop.hbase.http
-
- ProfileServlet.Event - Enum in org.apache.hadoop.hbase.http
-
- ProfileServlet.Output - Enum in org.apache.hadoop.hbase.http
-
- progress() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.CancelOnClose
-
- progress() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- progress - Variable in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
A different set of progress fields.
- progress() - Method in interface org.apache.hadoop.hbase.util.CancelableProgressable
-
Report progress.
- progress(FileStatus) - Method in interface org.apache.hadoop.hbase.util.FSUtils.ProgressReporter
-
- progress() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- progress() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- ProgressFields(int, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- progressSet - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- progressThreshold - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- promise - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- propagateBalancerConfigChange(QueueBalancer, Configuration) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- PropagatingConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
-
This extension to ConfigurationObserver allows the configuration to propagate to the children of
the current
ConfigurationObserver
.
- properties - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder.CoprocessorDescriptorImpl
-
- properties - Variable in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- properties - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- properties - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- PROPERTIES - Static variable in class org.apache.hadoop.hbase.logging.JulToSlf4jInitializer
-
- properties - Variable in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
- props - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- proto - Variable in class org.apache.hadoop.hbase.procedure2.store.ProtoAndProcedure
-
- proto - Variable in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- proto - Variable in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- ProtoAndProcedure - Class in org.apache.hadoop.hbase.procedure2.store
-
when loading we will iterator the procedures twice, so use this class to cache the deserialized
result to prevent deserializing multiple times.
- ProtoAndProcedure(ProcedureProtos.Procedure) - Constructor for class org.apache.hadoop.hbase.procedure2.store.ProtoAndProcedure
-
- ProtobufDecoder - Class in org.apache.hadoop.hbase.io.asyncfs
-
Modified based on io.netty.handler.codec.protobuf.ProtobufDecoder.
- ProtobufDecoder(Object) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- ProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
A Protobuf based WAL has the following structure:
- ProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- ProtobufLogReader.WALHdrContext - Class in org.apache.hadoop.hbase.regionserver.wal
-
- ProtobufLogReader.WALHdrResult - Enum in org.apache.hadoop.hbase.regionserver.wal
-
- ProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Writer for protobuf-based WAL.
- ProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- ProtobufMessageBodyConsumer - Class in org.apache.hadoop.hbase.rest.provider.consumer
-
Adapter for hooking up Jersey content processing dispatch to ProtobufMessageHandler interface
capable handlers for decoding protobuf input.
- ProtobufMessageBodyConsumer() - Constructor for class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- ProtobufMessageBodyProducer - Class in org.apache.hadoop.hbase.rest.provider.producer
-
An adapter between Jersey and ProtobufMessageHandler implementors.
- ProtobufMessageBodyProducer() - Constructor for class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- ProtobufMessageHandler - Interface in org.apache.hadoop.hbase.rest
-
Common interface for models capable of supporting protobuf marshalling and unmarshalling.
- protobufMessageLiteBuilderClass - Static variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- protobufMessageLiteClass - Static variable in class org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
-
- ProtobufStreamingOutput - Class in org.apache.hadoop.hbase.rest
-
- ProtobufStreamingOutput(ResultScanner, String, int, int) - Constructor for class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
-
- protocol - Variable in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- protocol - Variable in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- PROTOCOL - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- PROTOCOL_HTTP - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
-
- PROTOCOL_HTTPS - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
-
- provide() - Method in class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
-
- provider - Variable in class org.apache.hadoop.hbase.io.crypto.Cipher
-
- provider - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- provider - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- provider - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- provider - Variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- providerClass - Variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- providerId - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- providerId - Variable in class org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
-
- providerId - Variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- providers - Variable in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- providers - Variable in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
- Providers(Class<? extends WALProvider>) - Constructor for enum org.apache.hadoop.hbase.wal.WALFactory.Providers
-
- providersRef - Static variable in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- ProxyThrowable(String, StackTraceElement[]) - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignException.ProxyThrowable
-
- PROXYUSER_PREFIX - Static variable in class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
- ProxyUserAuthenticationFilter - Class in org.apache.hadoop.hbase.http
-
This file has been copied directly (changing only the package name and and the ASF license text
format, and adding the Yetus annotations) from Hadoop, as the Hadoop version that HBase depends
on doesn't have it yet (as of 2020 Apr 24, there is no Hadoop release that has it either).
- ProxyUserAuthenticationFilter() - Constructor for class org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
-
- pruneEntriesOlderThan(long, QuotaObserverChore) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- pruneNamespaceSnapshots(Multimap<TableName, String>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize
- pruneOldRegionReports() - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Removes region reports over a certain age.
- pruneTableSnapshots(Multimap<TableName, String>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
Removes the snapshot entries that are present in Quota table but not in snapshotsToComputeSize
- publish(ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- publish(ClusterMetrics) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- publisher - Variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- publishReadFailure(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
-
- publishReadFailure(ServerName, RegionInfo, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- publishReadFailure(ServerName, RegionInfo, ColumnFamilyDescriptor, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- publishReadFailure(String, String) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperStdOutSink
-
- publishReadTiming(String, String, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
-
- publishReadTiming(ServerName, RegionInfo, ColumnFamilyDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- publishReadTiming(String, String, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperStdOutSink
-
- publishSyncOnRingBuffer(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- publishSyncOnRingBuffer(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- publishSyncThenBlockOnCompletion(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- publishWriteFailure(ServerName, RegionInfo, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- publishWriteFailure(ServerName, RegionInfo, ColumnFamilyDescriptor, Exception) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- publishWriteTiming(ServerName, RegionInfo, ColumnFamilyDescriptor, long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- PureJavaComparer() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.ComparerHolder.PureJavaComparer
-
Deprecated.
- PureJavaComparer() - Constructor for enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.PureJavaComparer
-
- PureJavaConverter() - Constructor for class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- PureJavaConverter() - Constructor for class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.PureJavaConverter
-
- purge(long) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
If there were some calls that have not been sent out for a long time, we close the connection.
- purge() - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Removes stale references of shared objects from the pool.
- purgeAndGetEntryPoolSize() - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
For testing
- purgeExpiredTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- purgeLock - Variable in class org.apache.hadoop.hbase.util.ObjectPool
-
For preventing parallel purge
- purgeTimeout - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- push(Procedure, boolean, boolean) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- pushActiveToPipeline(MutableSegment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- pushData(WALProcedureStore.PushType, ByteSlot, long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- pushDownFilters - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- pushed - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- pushHead(MutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- pushPipelineToSnapshot() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- pushProcedure(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- pushTailToSnapshot() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- pushToSnapshot(List<ImmutableSegment>) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- PushType() - Constructor for enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
-
Deprecated.
- put(Put) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Puts some data to the table.
- put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Puts some data in the table, in batch.
- put(Put) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- put(ChannelHandlerContext, FullHttpRequest) - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- put(TableName, Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
The put request will be buffered by its corresponding buffer queue.
- put(TableName, List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
The puts request will be buffered by their corresponding buffer queue.
- put(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- put(TableName, Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
The put request will be buffered by its corresponding buffer queue.
- put(byte[], Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- put(byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- put - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.PutStatus
-
Deprecated.
- Put - Class in org.apache.hadoop.hbase.client
-
Used to perform Put operations for a single row.
- Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row.
- Put(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row, using a given timestamp.
- Put(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
- Put(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Put
-
- Put(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(byte[], boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for an immutable row key.
- Put(byte[], long, boolean) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for an immutable row key, using a given timestamp.
- Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Copy constructor.
- Put(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Construct the Put with user defined data.
- put(Put) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- put(Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
Puts some data in the table.
- put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Batch puts the specified data into the table.
- put(Field, Object) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
-
- put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
-
- put(Record.Entry) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
-
- put(Field, FieldValue) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- put(byte[], int) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Put the magic record out to the specified byte array position.
- put(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- put(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- put(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- put(E) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Inserts the specified element at the tail of the queue, if it's not already present.
- put(Table, Put) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- put(K, Supplier<V>) - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- put(byte) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a byte to this ByteBuff at the current position and increments the position
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a byte to this ByteBuff at the given index
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies from the given byte[] to this ByteBuff
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies from the given byte[] to this ByteBuff n * @return this ByteBuff
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Copies the contents from the src ByteBuff to this ByteBuff.
- put(byte) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a byte to this MBB at the current position and increments the position n * @return this
object
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a byte to this MBB at the given index and won't affect the position of any of the
buffers.
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from a src BB to this MBB.
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from the given byte[] to this MBB
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Copies from the given byte[] to this MBB.
- put(byte) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- put(int, ByteBuff, int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- put(byte[]) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- put(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- put(RegionInfo, long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Atomically sets the given size
for a region.
- put(RegionInfo, long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- put(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- put(Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- put(Put) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Puts some data in the table.
- put(HRegion, OperationQuota, ClientProtos.MutationProto, CellScanner, ActivePolicyEnforcement) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, String, byte[], Header) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(NamespacesInstanceModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.NamespacesInstanceResource
-
Build a response for PUT alter namespace with properties specified.
- put(CellSetModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- put(ScannerModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
-
- put(TableSchemaModel, UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- put(String, T) - Method in class org.apache.hadoop.hbase.security.access.AuthManager.PermissionCache
-
- put(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- put(Put) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- put(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- put(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- put(int, byte) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store val
at index
.
- put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store val
at index
.
- put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store length
bytes from val
into this range, starting at index
.
- put(byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store val
at the next position in this range.
- put(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store the content of val
in this range, starting at the next position.
- put(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store length
bytes from val
into this range.
- put(int, byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- PUT_BATCH_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- PUT_BATCH_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- PUT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- putAll(List<Put>) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
A simple version of batch put.
- putAll(Map<Field, FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record.Builder
-
- putAll(Map<? extends Field, ? extends FieldValue>) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- putAll(Map<? extends byte[], ? extends byte[]>) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- putAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Inserts the specified elements at the tail of the queue.
- putAll(Map<? extends Cell, ? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- putAllConfiguration(Map<String, String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Adds all of the provided "raw" configuration entries to this
.
- putAllFirst(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Inserts the specified elements at the head of the queue.
- putAllPeerData(Map<byte[], byte[]>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets all of the provided serialized peer configuration data.
- putAsShort(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putAsShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value as short out to the specified byte array position.
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
-
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- putBack(Cell) - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- putbackBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
Return back a ByteBuffer after its use.
- putbackBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator
-
- putbackChunks(Chunk) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
Add the chunks to the pool, when the pool achieves the max size, it will skip the remaining
chunks n
- putbackChunks(Set<Integer>) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- putBatchHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- putBatchTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a BigDecimal value out to the specified byte array position.
- putBinary(byte[], UriInfo, HttpHeaders) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- putByte(ByteBuffer, int, byte) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a single byte out to the specified byte array position.
- putByte(ByteBuffer, int, byte) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a byte value out to the specified BB position in big-endian format.
- putByteBuffer(byte[], int, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Add the whole content of the ByteBuffer to the bytes arrays.
- putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put bytes at the specified byte array position.
- putChar(int, int, char, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- putColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
-
Combine Puts.
- PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- putCompressedInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Put in buffer integer using 7 bit encoding.
- putConfiguration(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- putConfiguration(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets a "raw" configuration property for this replication peer.
- putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a double value out to the specified byte array position as the IEEE 754 double format.
- putFirst(E) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Inserts the specified element at the head of the queue.
- putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a float value out to the specified byte array position.
- putFromHBase(Put) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- putFromThrift(TPut) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
Put
(HBase) from a
TPut
(Thrift)
- putHeader(byte[], int, int, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Put the header into the given byte array at the given offset.
- putHeader(ByteBuff, int, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- putHeader(ByteArrayOutputStream, int, int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- putHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- putHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- putIfAbsent(BlockCacheKey, BucketCache.RAMQueueEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
Return the previous associated value, or null if absent.
- putIfAbsent(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Adds the server to the dead server list if it's not there already.
- putIfAbsent(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes an int to this ByteBuff at its current position.
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes an int to this MBB at its current position.
- putInt(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- putInt(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putInt(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putInt(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putInt(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putInt(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putInt(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Put in output stream 32 bit integer (Big Endian byte order).
- putInt(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Put an int value out to the given ByteBuffer's current position in big-endian format.
- putInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the int value at index
- putInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.Converter
-
- putInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.PureJavaConverter
-
- putInt(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.UnsafeConverter
-
- putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value out to the specified byte array position.
- putInt(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store int val
at the next position in this range.
- putInt(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putInt(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putInt(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put an int value out to the specified byte array position in big-endian format.
- putInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put an int value out to the specified ByteBuffer offset in big-endian format.
- putInternal(byte[]) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- putIntoBackingMap(BlockCacheKey, BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Put the new bucket entry into backingMap.
- putIntUnsafe(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Writes a long to this ByteBuff at its current position.
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Writes a long to this MBB at its current position.
- putLong(long) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- putLong(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putLong(ByteBuffer, int, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putLong(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putLong(ByteBuffer, int, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putLong(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putLong(ByteBuffer, int, long) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putLong(OutputStream, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putLong(ByteBuffer, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Put a long value out to the given ByteBuffer's current position in big-endian format.
- putLong(ByteBuffer, int, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the long value at index
- putLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.util.Bytes.Converter
-
- putLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.PureJavaConverter
-
- putLong(byte[], int, long) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.UnsafeConverter
-
- putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a long value out to the specified byte array position.
- putLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store long val
at the next position in this range.
- putLong(int, long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a long value out to the specified byte array position in big-endian format.
- putLong(ByteBuffer, int, long) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a long value out to the specified BB position in big-endian format.
- putLongUnsafe(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- putPeerData(byte[], byte[]) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- putPeerData(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the serialized peer configuration data
- putRowToTable(Table) - Static method in class org.apache.hbase.archetypes.exemplars.client.HelloHBase
-
Invokes Table#put to store a row (with two new columns created 'on the fly') into the table.
- putRowToTable(Table) - Static method in class org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
-
Invokes Table#put to store a row (with two new columns created 'on the fly') into the table.
- putsFromHBase(List<Put>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- putsFromThrift(List<TPut>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TPut
s (Thrift) into a list of
Put
s (HBase).
- putShort(ByteBuffer, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putShort(ByteBuffer, int, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.Converter
-
Deprecated.
- putShort(ByteBuffer, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putShort(ByteBuffer, int, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.PureJavaConverter
-
Deprecated.
- putShort(ByteBuffer, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putShort(ByteBuffer, int, short) - Method in class org.apache.hadoop.hbase.util.ByteBufferUtils.ConverterHolder.UnsafeConverter
-
Deprecated.
- putShort(ByteBuffer, short) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Put a short value out to the given ByteBuffer's current position in big-endian format.
- putShort(ByteBuffer, int, short) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the short value at index
- putShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.util.Bytes.Converter
-
- putShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.PureJavaConverter
-
- putShort(byte[], int, short) - Method in class org.apache.hadoop.hbase.util.Bytes.ConverterHolder.UnsafeConverter
-
- putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a short value out to the specified byte array position.
- putShort(short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store short val
at the next position in this range.
- putShort(int, short) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putShort(short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putShort(int, short) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a short value out to the specified byte array position in big-endian format.
- putShort(ByteBuffer, int, short) - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
Put a short value out to the specified BB position in big-endian format.
- putShortUnsafe(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Puts.
- PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- PutStatus(RegionInfo, Put, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.PutStatus
-
Deprecated.
- putsToMetaTable(Connection, List<Put>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Put the passed ps
to the hbase:meta
table.
- putString(int, int, String, Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- putTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- putToMetaTable(Connection, Put) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Put the passed p
to the hbase:meta
table.
- putTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- putUint32(PositionedByteRange, int) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Write a 32-bit unsigned integer to dst
as 4 big-endian bytes.
- putUpJettyServer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- putUpWebUI() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Puts up the webui.
- putUpWebUI() - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- putVaruint64(PositionedByteRange, long, boolean) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Encode an unsigned 64-bit unsigned integer val
into dst
.
- putVLong(int, long) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store the long value at index
as a VLong
- putVLong(long) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store the long val
at the next position as a VLong
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putVLong(long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- putVLong(int, long) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'R'
- r - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- r - Variable in class org.apache.hadoop.hbase.util.ReservoirSample
-
- RACK_LOCALITY_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.RackLocalityCostFunction
-
- rackLocalities - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- rackLocalityCost - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- RackLocalityCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
- RackLocalityCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.RackLocalityCostFunction
-
- rackManager - Variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- rackManager - Variable in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- rackManager - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- RackManager - Class in org.apache.hadoop.hbase.master
-
Wrapper over the rack resolution utility in Hadoop.
- RackManager() - Constructor for class org.apache.hadoop.hbase.master.RackManager
-
- RackManager(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RackManager
-
- rackManager - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- rackManager - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- rackManager - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- rackManager(RackManager) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
Set specific rackManager implementation.
- racks - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- racksToIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- rackToRegionServerMap - Variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- radix - Variable in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- RADIX_DEC - Static variable in class org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit
-
- RADIX_HEX - Static variable in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- raf - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
- rafs - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- ramCache - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- RAMCache() - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- RAMQueueEntry(BlockCacheKey, Cacheable, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
-
- random - Static variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- random - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- random - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- random(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes.
- random(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes at the specified position.
- Random64 - Class in org.apache.hadoop.hbase.util
-
An instance of this class is used to generate a stream of pseudorandom numbers.
- Random64() - Constructor for class org.apache.hadoop.hbase.util.Random64
-
- Random64(long) - Constructor for class org.apache.hadoop.hbase.util.Random64
-
- RANDOM_RADIX - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- RANDOM_WIDTH - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Used to assign a single region to a random server.
- randomAssignment(BalancerClusterState, RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Used to assign a single region to a random server.
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- randomAssignment(RegionInfo, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Get a random region server from the list
- randomAssignment(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- RandomCandidateGenerator - Class in org.apache.hadoop.hbase.master.balancer
-
- RandomCandidateGenerator() - Constructor for class org.apache.hadoop.hbase.master.balancer.RandomCandidateGenerator
-
- randomGenerator - Variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaCandidateGenerator
-
- randomGeneratorForTest - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
A random number generator to use for "fake lookups" when testing to estimate the ideal false
positive rate.
- RandomizedMatrix(int, int) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Create a randomization scheme for a matrix of a given size.
- randomPickOneColumnFamily(ColumnFamilyDescriptor[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- RandomQueueBalancer - Class in org.apache.hadoop.hbase.ipc
-
Queue balancer that just randomly selects a queue in the range [0, num queues).
- RandomQueueBalancer(Configuration, String, List<BlockingQueue<CallRunner>>) - Constructor for class org.apache.hadoop.hbase.ipc.RandomQueueBalancer
-
- RandomRowFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that includes rows based on a chance.
- RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Create a new filter with a specified chance for a row to be included.
- range - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- Range() - Constructor for enum org.apache.hadoop.hbase.io.Reference.Range
-
- RANGE_OF_DELAY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- RANGE_TYPE - Static variable in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- RANGE_TYPE - Static variable in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- rangeCmp - Variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- RangeIteration(List<MultiRowRangeFilter.RowRange>) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- rangeList - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- rangeOfDelayMs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- ranges - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- ranges - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- ranges - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- RANGES - Static variable in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- RANGES - Static variable in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- RATE_LIMIT_BYTES_PER_SEC_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- RATE_UNLIMITED_BYTES - Static variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- rateLimiter - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- RateLimiter - Class in org.apache.hadoop.hbase.quotas
-
Simple rate limiter.
- RateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.RateLimiter
-
- rateUnit - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter.Builder
-
- ratio - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- RatioBasedCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
The default algorithm for selecting files for compaction.
- RatioBasedCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- RAW_ATTR - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- RAW_SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.ExportUtils
-
- rawAdmin - Variable in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- RawAsyncHBaseAdmin - Class in org.apache.hadoop.hbase.client
-
The implementation of AsyncAdmin.
- RawAsyncHBaseAdmin(AsyncConnectionImpl, HashedWheelTimer, AsyncAdminBuilderBase) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- RawAsyncHBaseAdmin.AddColumnFamilyProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.AdminRpcCall<RESP,REQ> - Interface in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.Converter<D,S> - Interface in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.CreateNamespaceProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.CreateTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.DeleteColumnFamilyProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.DeleteNamespaceProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.DeleteTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.DisableTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.EnableTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.MasterRpcCall<RESP,REQ> - Interface in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.MergeTableRegionProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ModifyColumnFamilyProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ModifyColumnFamilyStoreFileTrackerProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ModifyNamespaceProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ModifyTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ModifyTableStoreFileTrackerProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.NamespaceProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.ReplicationProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.SplitTableRegionProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.TableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncHBaseAdmin.TruncateTableProcedureBiConsumer - Class in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of RawAsyncTable.
- RawAsyncTableImpl(AsyncConnectionImpl, Timer, AsyncTableBuilderBase<?>) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- RawAsyncTableImpl.CheckAndMutateBuilderImpl - Class in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl.CheckAndMutateWithFilterBuilderImpl - Class in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl.Converter<D,I,S> - Interface in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl.CoprocessorServiceBuilderImpl<S,R> - Class in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl.NoncedConverter<D,I,S> - Interface in org.apache.hadoop.hbase.client
-
- RawAsyncTableImpl.RpcCall<RESP,REQ> - Interface in org.apache.hadoop.hbase.client
-
- rawBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- RawByte - Class in org.apache.hadoop.hbase.types
-
- RawByte() - Constructor for class org.apache.hadoop.hbase.types.RawByte
-
- RawBytes - Class in org.apache.hadoop.hbase.types
-
- RawBytes() - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
- RawBytes(Order) - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
- RawBytesFixedLength - Class in org.apache.hadoop.hbase.types
-
- RawBytesFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a RawBytesFixedLength
using the specified order
and length
.
- RawBytesFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a RawBytesFixedLength
of the specified length
.
- RawBytesTerminated - Class in org.apache.hadoop.hbase.types
-
- RawBytesTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator and order
.
- RawBytesTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator and order
.
- RawBytesTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator.
- RawBytesTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator.
- RawCell - Interface in org.apache.hadoop.hbase
-
An extended version of Cell that allows CPs manipulate Tags.
- RawCellBuilder - Interface in org.apache.hadoop.hbase
-
Allows creating a cell with
Tag
An instance of this type can be acquired by using
RegionCoprocessorEnvironment#getCellBuilder (for prod code) and
RawCellBuilderFactory
(for unit tests).
- RawCellBuilderFactory - Class in org.apache.hadoop.hbase
-
Factory for creating cells for CPs.
- RawCellBuilderFactory() - Constructor for class org.apache.hadoop.hbase.RawCellBuilderFactory
-
- rawCells() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the array of Cells backing this Result instance.
- RawDouble - Class in org.apache.hadoop.hbase.types
-
- RawDouble() - Constructor for class org.apache.hadoop.hbase.types.RawDouble
-
- rawExpression() - Method in class org.apache.hadoop.hbase.security.access.NamespacePermission
-
- rawExpression() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- rawExpression() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- RawFloat - Class in org.apache.hadoop.hbase.types
-
- RawFloat() - Constructor for class org.apache.hadoop.hbase.types.RawFloat
-
- RawInteger - Class in org.apache.hadoop.hbase.types
-
- RawInteger() - Constructor for class org.apache.hadoop.hbase.types.RawInteger
-
- rawKVs - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- RawLong - Class in org.apache.hadoop.hbase.types
-
- RawLong() - Constructor for class org.apache.hadoop.hbase.types.RawLong
-
- rawMobScan - Variable in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- rawMobScan - Variable in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- rawRequest - Variable in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- rawScan - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- rawScanEnabled - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- rawScanEnabled - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- RawScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for raw scan.
- RawScanQueryMatcher(Scan, ScanInfo, ColumnTracker, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
-
- RawShort - Class in org.apache.hadoop.hbase.types
-
- RawShort() - Constructor for class org.apache.hadoop.hbase.types.RawShort
-
- rawStream - Variable in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- RawString - Class in org.apache.hadoop.hbase.types
-
- RawString() - Constructor for class org.apache.hadoop.hbase.types.RawString
-
- RawString(Order) - Constructor for class org.apache.hadoop.hbase.types.RawString
-
- RawStringFixedLength - Class in org.apache.hadoop.hbase.types
-
- RawStringFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a RawStringFixedLength
using the specified order
and length
.
- RawStringFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a RawStringFixedLength
of the specified length
.
- RawStringTerminated - Class in org.apache.hadoop.hbase.types
-
- RawStringTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator and order
.
- RawStringTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator and order
.
- RawStringTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator.
- RawStringTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator.
- rawTable - Variable in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- REACHED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- reachedZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- read() - Method in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
Call the delegate's read()
method if the current position is less than the limit.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
Call the delegate's read(byte[], int, int)
method if the current position is less than
the limit.
- read() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Reads the next byte of data from this input stream.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Reads up to next len
bytes of data from buffer into passed array(starting from
given offset).
- read() - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Reads the next byte of data from this input stream.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Reads up to next len
bytes of data from buffer into passed array(starting from
given offset).
- read() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- read(byte[]) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- read(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- read() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read(byte[]) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
- read(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Read bytes starting from the specified position.
- read(DataInputStream) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- read(ByteBuff) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- read(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
- read(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ExclusiveMemoryMmapIOEngine
-
- read(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Transfers data from file to the given byte buffer
- read(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
- read(BucketEntry) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Transfers data from IOEngine to a Cacheable object.
- read(BucketEntry) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.SharedMemoryMmapIOEngine
-
- read(DataInputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
Populate this instance with what we find on the passed in in
stream.
- read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
-
Read a Reference from FileSystem.
- read(int) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection.ByteBuffByteInput
-
- read(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection.ByteBuffByteInput
-
- read(int, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection.ByteBuffByteInput
-
- read(Configuration, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- read(ReadableByteChannel, ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.nio.ByteBuff.ChannelReader
-
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Reads bytes from the given channel into this ByteBuf.
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Reads bytes from FileChannel into this ByteBuff
- read(ReadableByteChannel, ByteBuffer, long, ByteBuff.ChannelReader) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- read(ReadableByteChannel) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- read(FileChannel, long) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- read(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- read() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(byte[]) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(DataInput) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Read from in
- read() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient.WrappedInputStream
-
- read(byte[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient.WrappedInputStream
-
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient.WrappedInputStream
-
- read() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- read(long, ByteBuff) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfers bytes from this buffers array into the given destination
ByteBuff
- read4Bytes() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- READ_CAPACITY_UNIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- READ_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
- READ_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
- READ_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- READ_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- READ_REQUEST_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.ReadRequestCostFunction
-
- READ_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- READ_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- READ_REQUEST_RATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- READ_REQUEST_RATE_PER_SECOND - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- READ_TIMEOUT - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- READ_TIMEOUT_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- READ_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
Indicated the type of read.
- readAccessor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- readahead - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- readAllCF - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- readAllCF - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- readAllVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- readAllVersions() - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- readAndCheck(DataInputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given stream and expects it
to match this block type.
- readAndCheck(ByteBuffer) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given byte buffer and expects
it to match this block type.
- readAndProcess() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
Read off the wire.
- readAndUpdateNewBlock(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- readAsInt(ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Converts a ByteBuffer to an int value
- readAsInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- readAsVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a zero-compressed encoded long from input buffer and returns it.
- readAtOffset(FSDataInputStream, ByteBuff, int, boolean, long, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Does a positional read or a seek and read into the given byte buffer.
- readAvailable - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readBalancer - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
-
Read in a file block.
- readBlock(long, long, boolean, boolean, boolean, boolean, BlockType, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- readBlockData(long, long, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Reads the block at the given offset in the file with the given on-disk size and uncompressed
size.
- readBlockData(long, long, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Reads a version 2 block (version 1 blocks not supported and not expected).
- readBlockDataInternal(FSDataInputStream, long, long, boolean, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Reads a version 2 block.
- readByteArray(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec.CellDecoder
-
Returns Byte array read from the stream.
- readByteArray(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags.CellDecoder
-
Returns Byte array read from the stream.
- readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- readCapacityUnit - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readCapacityUnitConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readCapacityUnitDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readCapacityUnitLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- readCell(Cell, boolean) - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Reads a cell from the mob file.
- readCell(Cell, boolean, long) - Method in class org.apache.hadoop.hbase.mob.MobFile
-
Reads a cell from the mob file.
- readCell(List<Path>, String, Cell, boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from a mob file.
- readChunked(DataInput, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.Result94Deserializer
-
- readClusterIdZNode(ZKWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- readColumnFamily(Table, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- readCompleted() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
Indicate that the scanner has finished reading with this reader.
- readCompressed(DataInput, Dictionary) - Static method in class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
Deprecated.
- readCompressedInt(ByteBuff) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Read integer from ByteBuff coded in 7 bits and increment position.
- readCompressedInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Read integer from stream coded in 7 bits and increment position.
- readCompressedInt(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Read integer from buffer coded in 7 bits and increment position.
- readCompressedValue(InputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- readConf(Configuration) - Method in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
- readConfiguration(byte[]) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Read the Configuration
stored in the byte stream.
- readConfiguration(String) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Read in the configuration from the String encoded configuration n * to read from
- readConsumed - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readCryptoProps(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- readDataManifest() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- readDeleteEntry(ProcedureProtos.ProcedureWALEntry) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- readDiff - Variable in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- readEmptyValueOnMobCellMiss - Variable in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- readEmptyValueOnMobCellMiss - Variable in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- readEntry(InputStream) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
Deprecated.
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
Used to load chunks on demand
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- Reader() - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
-
Deprecated.
- Reader(Configuration, ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash.Reader
-
- reader - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- reader - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- reader - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- reader - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- reader - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- READER - Static variable in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfer bytes from source
ByteBuffer
to destination
ByteBuff
, Position of both
source and destination will be advanced.
- ReaderBase - Class in org.apache.hadoop.hbase.regionserver.wal
-
- ReaderBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Default constructor.
- ReaderContext - Class in org.apache.hadoop.hbase.io.hfile
-
Carries the information on some of the meta data about the HFile Reader
- ReaderContext(Path, FSDataInputStreamWrapper, long, HFileSystem, boolean, ReaderContext.ReaderType) - Constructor for class org.apache.hadoop.hbase.io.hfile.ReaderContext
-
- ReaderContext.ReaderType - Enum in org.apache.hadoop.hbase.io.hfile
-
- ReaderContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
-
A builder that helps in building up the ReaderContext
- ReaderContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
-
- readerPendingConnectionQueueLength - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- readers - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- readerThread() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- ReaderType() - Constructor for enum org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
-
- ReadExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
-
- readFailureCount - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- readFailures - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter.MetaWriter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Reference
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Reads the values of each field.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.NamespacePermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeTokenIdentifier
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportSnapshotInputFormat.ExportSnapshotInputSplit
-
- readFieldsFromPb(WALProtos.WALKey, WALCellCodec.ByteStringUncompressor) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- readFile(String) - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
used to read the rule files from either HDFS or local FS
- readFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
- readFileFromHDFS(String) - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
used to read the rule files from HDFS
- readFileFromLocalFS(String) - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
used to read the rule files from local FS
- readFrom(Class<ProtobufMessageHandler>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- readFromCells(Codec.Decoder, int) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
Reads WALEdit from cells.
- readFromStream(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Reads a file trailer from the given file.
- readFully(long, byte[]) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- readFully(long, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- readFully(ByteBuff, FSDataInputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read length bytes into ByteBuffers directly.
- readFullyWithHeapBuffer(InputStream, ByteBuff, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Copying bytes from InputStream to
ByteBuff
by using an temporary heap byte[] (default
size is 1024 now).
- readHandlersCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- readHandlerStack - Variable in class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
-
- readHeader(InputStream) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
Deprecated.
- readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- readHeader(WALProtos.WALHeader.Builder, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- readingSnapshot - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- readInitEntry(ProcedureProtos.ProcedureWALEntry) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- readInsertEntry(ProcedureProtos.ProcedureWALEntry) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- readIntoArray(byte[], int, Dictionary) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.CompressedKvDecoder
-
- readKey(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
Analyze the key and fill the state.
- readKey(ByteBuffer, int, int, int, CompressionState) - Method in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
Analyze the key and fill the state assuming we know previous state.
- readKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- readLabelsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Reads back from the zookeeper.
- readLatency - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- readLines(BufferedReader) - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
- readLock() - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- readLock - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
-
- readLock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Acquire read lock of this store.
- readLong(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- readLong(ByteBuff, int) - Static method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Read long which was written to fitInBytes bytes and increment position.
- readLong(InputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Read long which was written to fitInBytes bytes and increment position.
- readLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Read long which was written to fitInBytes bytes and increment position.
- readMetaState(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- readMultiLevelIndexRoot(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read the root-level metadata of a multi-level block index.
- readMvccVersion(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Read mvcc.
- readMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
read the content of znode file, expects a single line.
- readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- readNext(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Read next entry.
- readNext(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return the successor of the current node
- readNextDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Scans blocks in the "scanned" section of the
HFile
until the next data block is
found.
- readNextEntryAndRecordReaderPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
Returns whether the file is opened for writing.
- readNextRpcPacket() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient.WrappedInputStream
-
- readonly - Variable in class org.apache.hadoop.hbase.client.Result
-
- READONLY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by rest interface to access this metadata attribute which denotes if the table is Read
Only.
- READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- readOnly - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- readOnly() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Deprecated.
Is this operation read only? If this is true, process() should not add any mutations or it
throws IOException.
- READONLY - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- READONLY_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- READONLY_LOGGERS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel
-
- READONLY_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- ReadOnlyByteRangeException - Exception in org.apache.hadoop.hbase.util
-
Exception thrown when a read only byte range is modified
- ReadOnlyByteRangeException() - Constructor for exception org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
-
- ReadOnlyConfiguration - Class in org.apache.hadoop.hbase.coprocessor
-
Wraps a Configuration to make it read-only.
- ReadOnlyConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- readOnlyCopy - Variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- readOnlyNamespaceSnapshots - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- readOnlyTableQuotaSnapshots - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- ReadOnlyZKClient - Class in org.apache.hadoop.hbase.zookeeper
-
A very simple read only zookeeper implementation without watcher support.
- ReadOnlyZKClient(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- ReadOnlyZKClient.Task - Class in org.apache.hadoop.hbase.zookeeper
-
- ReadOnlyZKClient.ZKTask<T> - Class in org.apache.hadoop.hbase.zookeeper
-
- readOpLatency - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- readPartitionFile(FileSystem, Configuration, Path) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- readPasswordDB(Configuration) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- readPermissions(byte[], Configuration) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- readPoint - Variable in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- readPoint - Variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- readPoint - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- READPOINT_ADVANCE_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- readPool - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- readPreamble() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- readPrev(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Return the predecessor of the current node
- readPropertiesFile(FileSystem, Path) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- readPt - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- readPt - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- readPt - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- readRawVarint32(InputStream) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- readRawVarint32(ByteBuff) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- readRawVarint32(byte[], int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
Reads a varInt value stored in an array.
- readRawVarint32(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- readRawVarint32(ByteBuf) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
Reads variable length 32bit int from buffer This method is from ProtobufVarint32FrameDecoder in
Netty and modified a little bit to pass the cyeckstyle rule.
- readRegionsFromFile(String) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- readReqsLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- 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.
- ReadRequestCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.ReadRequestCostFunction
-
- readRequestCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- readRequestCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- readRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- readRequestCount - Variable in class org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
-
- readRequestCountPerSecond - Variable in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl.ClientMetricsImpl
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- readRequestsCount - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- readRequestsRatePerSecond - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- readResponse() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- readResponse(ChannelHandlerContext, ByteBuf) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcDuplexHandler
-
- readRootIndex(DataInput, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readRootIndex(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readRpcTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- readRpcTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- readRpcTimeout - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- readRpcTimeout - Variable in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- readRpcTimeoutMs - Variable in class org.apache.hadoop.hbase.client.HTable
-
- readRpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- readRpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- readRpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- readSelector - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
-
Deprecated.
- readsEnabled - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- readServersFromFile(String) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- readSizeLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- readSnapshotInfo(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Read in the HBaseProtos.SnapshotDescription
stored for the snapshot in the passed directory
- readsOnlyFromMemstore - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- readStatistics - Static variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- ReadStatistics() - Constructor for class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper.ReadStatistics
-
- readStatus(DataInputStream) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- readStringFixedSize(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a fixed-size field and interprets it as a string padded with zeros.
- readSuccess - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- readSuccessCount - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- readThreads - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
-
- readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffCompressionState
-
- readTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- readTracker() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- readTrailer() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- readTrailer(FSDataInputStream, long, long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
Deprecated.
- readType - Variable in class org.apache.hadoop.hbase.client.Scan
-
Control whether to use pread at server side.
- ReadType() - Constructor for enum org.apache.hadoop.hbase.client.Scan.ReadType
-
- readType - Variable in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
- readType - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- ReadType() - Constructor for enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.ReadType
-
- readTypeFromHBase(Scan.ReadType) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- readTypeFromThrift(TReadType) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- readUnlock() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Release read lock of this store.
- readUpdateEntry(ProcedureProtos.ProcedureWALEntry) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- readUserAuthsFromZKData(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Reads back User auth data written to zookeeper.
- readUserPermission(byte[], Configuration) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- readVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- readVIntValuePart(Tag, int) - Static method in class org.apache.hadoop.hbase.TagUtil
-
Reads an int value stored as a VInt at tag's given offset.
- readVLong(ByteBufferUtils.ByteVisitor) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- readVLong(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Similar to
WritableUtils.readVLong(DataInput)
but reads from a
ByteBuffer
.
- readVLong(ByteBuff) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Similar to
WritableUtils.readVLong(java.io.DataInput)
but reads from a
ByteBuff
.
- readVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- readWaiters - Variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- readWALEntries(WALEntryStream, WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- readWALEntries(WALEntryStream, WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationSourceWALReader
-
- readWithExtra(ByteBuff, FSDataInputStream, int, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read bytes into ByteBuffers directly, those buffers either contains the extraLen bytes or only
contains necessaryLen bytes, which depends on how much bytes do the last time we read.
- readWithExtraOnHeap(InputStream, byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
-
Read from an input stream at least necessaryLen
and if possible,
extraLen
also if available.
- readWritableUserPermission(DataInput, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- readWriteLatency - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- readWriteLock - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- ready - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
- ReadyChunk() - Constructor for class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter.ReadyChunk
-
- readyChunks - Variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- readyForRolling - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- readyForRollingCond - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- readyToWriteCount - Variable in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- readZKNodes(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
- readZKTimestamp - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- realCacheSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- reallocate(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- realSeekDone() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
We optimize our store scanners by checking the most recent store file first, so we sometimes
pretend we have done a seek but delay it until the store scanner bubbles up to the top of the
key-value heap.
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
This scanner is working solely on the in-memory MemStore and doesn't work on store files,
MutableCellSetSegmentScanner always does the seek, therefore always returning true.
- realSeekDone - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- realUser - Variable in class org.apache.hadoop.hbase.rest.RESTServlet
-
- realUser - Variable in class org.apache.hadoop.hbase.util.ConnectionCache
-
- realUserName - Variable in class org.apache.hadoop.hbase.util.ConnectionCache
-
- reason - Variable in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
-
- reason - Variable in class org.apache.hadoop.hbase.client.BalancerRejection
-
- reason - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
-
- REASSIGN_WAIT_INTERVAL_KEY - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- reassigns - Variable in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure.UnknownServerVisitor
-
- rebuildCache() - Method in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
Rebuild cache matching ServerNames and their capacity.
- recalculateSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Recalculate the size of the compaction based on current files.
- receive(ClusterMetrics) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener
-
Acts upon the reception of a new cluster status.
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- receive(ForeignException) - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener
-
Receive a ForeignException.
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
A callback that handles incoming ForeignExceptions.
- receiveAbortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Send abort to the specified procedure
- RECEIVED_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- RECEIVED_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- receivedBytes(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- receivedBytes(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- receivedBytes - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- receivedBytes(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- receivedReachedGlobalBarrier(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Notification that procedure coordinator has reached the global barrier
- receivedReachedGlobalBarrier(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Pass along the procedure global barrier notification to any listeners
- receivedRequest(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- receivedRequest(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- receivedRequest(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- receiveGlobalFailure(MultiAction, ServerName, int, Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Resubmit all the actions from this multiaction after a failure.
- receiveMultiAction(MultiAction, ServerName, MultiResponse, int) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Called when we receive the result of a server query.
- receiveReachedGlobalBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Callback for the member rpcs to call when the global barrier has been reached.
- receiveTime - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- recheckServersTimeout - Variable in class org.apache.hadoop.hbase.ipc.FailedServers
-
- reckonDelta(Cell, Cell, byte[], long, Mutation, Function<Cell, byte[]>) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- reckonDeltas(Mutation, List<Cell>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- reckonDeltasByStore(HStore, Mutation, long, List<Cell>, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column
family/Store.
- reclaimed - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- reclaimedChunks - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- reclaimMemStoreMemory() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Check if the regionserver's memstore memory usage is greater than the limit.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove decommission marker from a region server to allow regions assignments.
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- recommissionRegionServer(RpcController, MasterProtos.RecommissionRegionServerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Remove decommission marker (previously called 'draining') from a region server to allow regions
assignments.
- recommissionRegionServer(RpcController, MasterProtos.RecommissionRegionServerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- reconfigNotification - Variable in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- reconfigure(int, int[], long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- reconnect(KeeperException) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
A private method used to re-establish a zookeeper session with a peer cluster.
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- reconnectToPeerCluster() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- Record - Class in org.apache.hadoop.hbase.hbtop
-
Represents a record of the metrics in the top screen.
- Record(ImmutableMap<Field, FieldValue>) - Constructor for class org.apache.hadoop.hbase.hbtop.Record
-
- Record.Builder - Class in org.apache.hadoop.hbase.hbtop
-
- Record.Entry - Class in org.apache.hadoop.hbase.hbtop
-
- RECORD_HEADER_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- RECORD_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- recordCacheHit() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- recordCacheMiss() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- recordCanPush(String, long, long[], int) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- recordClearRegionCache() - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- recordEviction() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
Records an eviction.
- RecordFilter - Class in org.apache.hadoop.hbase.hbtop
-
Represents a filter that's filtering the metric
Record
s.
- RecordFilter(boolean, boolean, Field, RecordFilter.Operator, FieldValue) - Constructor for class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- RecordFilter.FilterBuilder - Class in org.apache.hadoop.hbase.hbtop
-
- RecordFilter.Operator - Enum in org.apache.hadoop.hbase.hbtop
-
- recordLastFlushTime() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- recordLastResult(Result) - Method in class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
-
- recordLastResult(Result) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- recordMetaRegion() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Record the location of the hbase:meta region as found in ZooKeeper.
- recordMutationWithoutWal(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Update LongAdders for number of puts without wal and the size of possible data loss.
- recordNewServerWithLock(ServerName, ServerMetrics) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Adds the onlineServers list.
- RecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- recordReaderImpl - Variable in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- recordReaderImpl - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
- recordReadOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for read operations.
- recordReadOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- records - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- recordsSize - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
-
- recordSyncOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for sync operations.
- recordSyncOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- recordWriteOperationLatency(long) - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
Record the latency incurred for write operations.
- recordWriteOperationLatency(long) - Method in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
-
A zookeeper that can handle 'recoverable' errors.
- RecoverableZooKeeper(String, int, Watcher, int, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- recoverableZooKeeper - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
- recoverAndClose(CancelableProgressable) - Method in interface org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
-
The close method when error occurred.
- recoverAndClose(CancelableProgressable) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
The close method when error occurred.
- recoverAndClose(CancelableProgressable) - Method in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- recoverDFSFileLease(DistributedFileSystem, Path, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
- recovered - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- recovered - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
- RECOVERED_HFILES_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
- RECOVERED_LOG_TMPFILE_SUFFIX - Static variable in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- RecoveredEditsOutputSink - Class in org.apache.hadoop.hbase.wal
-
Class that manages the output streams from the log splitting process.
- RecoveredEditsOutputSink(WALSplitter, WALSplitter.PipelineController, EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
-
- RecoveredEditsWriter(byte[], Path, WALProvider.Writer, long) - Constructor for class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
-
- recoveredMasterLock - Variable in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- RecoveredReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
Class that handles the recovered source of a replication stream, which is transfered from another
dead region server.
- RecoveredReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
-
- RecoveredReplicationSourceShipper - Class in org.apache.hadoop.hbase.replication.regionserver
-
- RecoveredReplicationSourceShipper(Configuration, String, ReplicationSourceLogQueue, RecoveredReplicationSource, ReplicationQueueStorage) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- recoverFileLease(FileSystem, Path) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.FsUtilsLeaseRecovery
-
- recoverFileLease(FileSystem, Path) - Method in interface org.apache.hadoop.hbase.procedure2.store.LeaseRecovery
-
- recoverFileLease(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
- recoverFileLease(FileSystem, Path, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
Recover the lease from HDFS, retrying multiple times.
- recoverLease() - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- recoverLease() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
- recoverLease() - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- recoverLease() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- recoverLease(Configuration, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- recoverLease(DistributedFileSystem, int, Path, long) - Static method in class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
Try to recover the lease.
- recoverLease(Configuration, Path) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- RecoverLeaseFSUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for recovering file lease for hdfs.
- RecoverLeaseFSUtils() - Constructor for class org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
-
- RecoverMetaProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- RecoverMetaProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- RECOVERY_RETRY - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- RECOVERY_RETRY_INTERVAL_MILLIS - Static variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- recreateRegionInfo(List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- recreateScanners(List<KeyValueScanner>, boolean, boolean, boolean, ScanQueryMatcher, byte[], boolean, byte[], boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Recreates the scanners on the current list of active store file scanners
- recreateZKConnection() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- recursive - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
-
- recycleChunks() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
- recycler - Variable in class org.apache.hadoop.hbase.nio.RefCnt
-
- reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
This function is called while parsing the filterString and an operator is parsed
- reduce(ImmutableBytesWritable, Iterator<Put>, OutputCollector<ImmutableBytesWritable, Put>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
No aggregation, output pairs of (key, record) nnnnn
- reduce(Key, Iterable<LongWritable>, Reducer<Key, LongWritable, Key, LongWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter.LongSumReducer
-
- reduce(ImmutableBytesWritable, Iterable<Cell>, Reducer<ImmutableBytesWritable, Cell, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellSortReducer
-
- reduce(Writable, Iterable<Mutation>, Reducer<Writable, Mutation, Writable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
Writes each given record, consisting of the row key and the given values, to the configured
OutputFormat
.
- reduce(Import.CellWritableComparable, Iterable<Cell>, Reducer<Import.CellWritableComparable, Cell, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellReducer
-
- reduce(Import.KeyValueWritableComparable, Iterable<KeyValue>, Reducer<Import.KeyValueWritableComparable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueReducer
-
Deprecated.
- reduce(ImmutableBytesWritable, Iterable<KeyValue>, Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
-
Deprecated.
- reduce(K, Iterable<Put>, Reducer<K, Put, K, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- reduce(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- reduce(ImmutableBytesWritable, Iterable<Text>, Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- reduce(Text, Iterable<ImmutableBytesWritable>, Reducer<Text, ImmutableBytesWritable, Text, Text>.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- REENTRANT_LOCK - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ReentrantReadWriteLock
- ref - Variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- REF_NAME_PATTERN - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Regex that will work for straight reference names (<hfile>.<parentEncRegion>
) and
hfilelink reference names (<table>
=<region>-<hfile>.<parentEncRegion>
) If reference, then the regex has more than just one
group.
- REF_OR_HFILE_LINK_PATTERN - Static variable in class org.apache.hadoop.hbase.io.HFileLink
-
The pattern should be used for hfile and reference links that can be found in
/hbase/table/region/family/
- refCellTags - Variable in class org.apache.hadoop.hbase.regionserver.HMobStore
-
- refCnt - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- refCnt() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- refCnt() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Reference count of this Cacheable.
- refCnt() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
-
- refCnt() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- refCnt - Variable in class org.apache.hadoop.hbase.nio.ByteBuff
-
- refCnt() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
- RefCnt - Class in org.apache.hadoop.hbase.nio
-
- RefCnt(ByteBuffAllocator.Recycler) - Constructor for class org.apache.hadoop.hbase.nio.RefCnt
-
- refCnt - Variable in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
-
- refCnt - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
-
Its initial value is 1, so it is one bigger than the current count of open scanners which
reading data from this MemStoreLAB.
- refCount - Variable in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap.Payload
-
- refCount - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- refCount - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- RefCountingMap<K,V> - Class in org.apache.hadoop.hbase.metrics.impl
-
A map of K to V, but does ref counting for added and removed values.
- RefCountingMap() - Constructor for class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- RefCountingMap.Payload<V> - Class in org.apache.hadoop.hbase.metrics.impl
-
- Reference - Class in org.apache.hadoop.hbase.io
-
A reference to the top or bottom half of a store file where 'bottom' is the first half of the
file containing the keys that sort lowest and 'top' is the second half of the file with keys that
sort greater than those of the bottom half.
- Reference(byte[], Reference.Range) - Constructor for class org.apache.hadoop.hbase.io.Reference
-
Constructor
- Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
-
- reference - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- reference - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
- Reference.Range - Enum in org.apache.hadoop.hbase.io
-
For split HStoreFiles, it specifies if the file covers the lower half or the upper half of the
key range
- REFERENCE_COUNT_NAME - Static variable in class org.apache.hadoop.hbase.nio.ByteBuff
-
- ReferenceAndLinkFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
-
- referenceCache - Variable in class org.apache.hadoop.hbase.util.ObjectPool
-
Does not permit null keys.
- referenceCount - Variable in class org.apache.hadoop.hbase.mob.CachedMobFile
-
- referencedMobCells - Variable in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- referencedMobCells - Variable in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- referenceFileCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- ReferenceFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
-
- ReferenceType() - Constructor for enum org.apache.hadoop.hbase.util.IdReadWriteLock.ReferenceType
-
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- refill(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Refill the available units w.r.t the elapsed time.
- refillKVS() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
- ReflectionUtils - Class in org.apache.hadoop.hbase.util
-
- ReflectionUtils() - Constructor for class org.apache.hadoop.hbase.util.ReflectionUtils
-
- refresh() - Method in interface org.apache.hadoop.hbase.client.RegistryEndpointsRefresher.Refresher
-
- refresh(long, long, long, long) - Method in class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- refresh(boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- refresh() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- refresh() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- refresh() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- refresh() - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- refresh() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Refresh/reload the group information from the persistent store
- refresh() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- refresh(boolean) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
Read rsgroup info from the source of truth, the hbase:rsgroup table.
- refresh(Hbase.Client, THttpClient) - Method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- REFRESH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- REFRESH_DEFAULT_PERIOD - Static variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.http.ProfileOutputServlet
-
- REFRESH_REPLICA_COUNT_CHORE_INTERVAL_IN_MILLISECONDS - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- refreshAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Refreshing the age makes sure the value returned is the actual one and not the one set a
replication time
- refreshAgeOfLastShippedOp(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Convenience method to use the last given timestamp to refresh the age of the last edit.
- refreshAndGetReplicationLoad() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Refresh and Get ReplicationLoad
- refreshAndGetReplicationLoad() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- refreshAndGetReplicationLoad() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- refreshAndWait(Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- refreshAuthManager(Configuration, PolicyProvider) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- refreshAuthManager(Configuration, PolicyProvider) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Refresh authentication manager policy.
- refreshAuthManager(String, byte[]) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- refreshCache() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- RefreshCacheTask() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- refreshCatalogReplicaCount() - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- refreshChore - Variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- refreshConfig() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- refreshConfiguration(Configuration) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- refreshDelay - Variable in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
-
- refreshDelay - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- refresher - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- refreshFileConnection(int, IOException) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- refreshHFiles(TableName) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- refreshHFiles(Table) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- refreshHFiles(RpcController, RefreshHFilesProtos.RefreshHFilesRequest, RpcCallback<RefreshHFilesProtos.RefreshHFilesResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
-
- RefreshHFilesClient - Class in org.apache.hadoop.hbase.client.example
-
This client class is for invoking the refresh HFile function deployed on the Region Server side
via the RefreshHFilesService.
- RefreshHFilesClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
Constructor with Conf object
- RefreshHFilesEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
-
Coprocessor endpoint to refresh HFiles on replica.
- RefreshHFilesEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
-
- refreshKeys() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
refresh keys
- refreshLabelsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- refreshLocalityChangedRegions(ClusterMetrics, ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
If locality for a region has changed, that pretty certainly means our cache is out of date.
- refreshMetricsData() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- refreshNamespaceCacheFromWritable(String, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Update acl info for namespace.
- refreshNodes(List<ZKUtil.NodeAndData>) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- refreshNodes(List<ZKUtil.NodeAndData>) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- refreshNodes(List<ZKUtil.NodeAndData>) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- refreshNow - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- refreshNow() - Method in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
Notifies the refresher thread to refresh the configuration.
- refreshPeer(MasterProcedureEnv, PeerProcedureInterface.PeerOperationType) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- RefreshPeerCallable - Class in org.apache.hadoop.hbase.replication.regionserver
-
The callable executed at RS side to refresh the peer config/state.
- RefreshPeerCallable() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RefreshPeerCallable
-
- refreshPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- RefreshPeerProcedure - Class in org.apache.hadoop.hbase.master.replication
-
- RefreshPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- RefreshPeerProcedure(String, PeerProcedureInterface.PeerOperationType, ServerName) - Constructor for class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- refreshPeerState(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- refreshPeerState(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- refreshRecords(ClusterMetrics) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- refreshSources(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Close the previous replication sources of this peer id and open new sources to trigger the new
replication state changes or new replication config changes.
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- refreshStoreFiles(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- refreshStoreFiles(Collection<String>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Replaces the store files that the store has with the given files.
- refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the region's underlying store files, open the files that have not been opened yet, and
remove the store file readers for store files no longer available.
- refreshStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Checks the underlying store files, and opens the files that have not been opened, and removes
the store file readers for store files no longer available.
- refreshStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- refreshStoreFiles(Collection<String>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- refreshStoreFilesAndReclaimMemory(Region) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- refreshStoreFilesInternal(Collection<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Checks the underlying store files, and opens the files that have not been opened, and removes
the store file readers for store files no longer available.
- refreshStoreSizeAndTotalBytes() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Update counts.
- refreshStubs() - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- refreshSummary(ClusterMetrics) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- refreshTableCacheFromWritable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Update acl info for table.
- refreshTerminal() - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- refreshTimeout() - Method in class org.apache.hadoop.hbase.procedure2.InlineChore
-
- refreshTimer - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- refreshUserAuthsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- refreshUserAuthsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- refreshVisibilityLabelsCache(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- refreshWatchingList() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- refType - Variable in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- regex - Variable in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
-
- regex(String) - Method in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
-
- regex - Variable in class org.apache.hadoop.hbase.client.NormalizeTableFilterParams
-
- regex - Variable in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- regex - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- RegexStringComparator - Class in org.apache.hadoop.hbase.filter
-
- RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator.Engine - Interface in org.apache.hadoop.hbase.filter
-
This is an internal interface for abstracting access to different regular expression matching
engines.
- RegexStringComparator.EngineType - Enum in org.apache.hadoop.hbase.filter
-
Engine implementation type (default=JAVA)
- RegexStringComparator.JavaRegexEngine - Class in org.apache.hadoop.hbase.filter
-
Implementation of the Engine interface using Java's Pattern.
- RegexStringComparator.JoniRegexEngine - Class in org.apache.hadoop.hbase.filter
-
Implementation of the Engine interface using Jruby's joni regex engine.
- regexStringNoCaseType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringNoCaseType byte array
- regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringType byte array
- region - Variable in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- region - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- region - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- region - Variable in class org.apache.hadoop.hbase.io.Reference
-
- region - Variable in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- region - Variable in class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
-
- region - Variable in class org.apache.hadoop.hbase.master.balancer.MoveRegionAction
-
- region - Variable in class org.apache.hadoop.hbase.master.MasterRegionServerList
-
- region - Variable in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- region - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- region - Variable in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure.RegionFlushTask
-
- region - Variable in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
The region configured for this flush policy.
- region - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- region - Variable in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- Region - Interface in org.apache.hadoop.hbase.regionserver
-
Region is a subset of HRegion with operations required for the
Coprocessors
.
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
The region
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
The region configured for this split policy.
- region - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- region - Variable in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- Region() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Default constructor
- Region(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- Region(byte[], int, int, int, int, long, long, long, int, int, int, long, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- region - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- region - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- region - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- region - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- region - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
-
- region - Variable in class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- region - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- Region.Operation - Enum in org.apache.hadoop.hbase.regionserver
-
- Region.RowLock - Interface in org.apache.hadoop.hbase.regionserver
-
Row lock held by a given thread.
- REGION_COPROC_METRICS_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- REGION_COPROC_METRICS_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- REGION_COPROC_METRICS_JMX_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- REGION_COPROC_METRICS_NAME - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- REGION_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- REGION_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- REGION_COUNT_SKEW_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
Cost for the function.
- REGION_COUNT_SKEW_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- REGION_EVENT - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- REGION_EVENT_CLOSE - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
We use this define figuring if we are carrying a close event.
- REGION_EVENT_PREFIX - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- REGION_EVENT_PREFIX_STR - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- REGION_EVENT_STR - Static variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- REGION_GROUPING_STRATEGY - Static variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- REGION_ID - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_INFO_FILE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Name of the region info file that resides just under the region directory.
- REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
The flag to indicate whether or not the memstore should be replicated for read-replicas
(CONSISTENCY => TIMELINE).
- REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- REGION_MEMSTORE_REPLICATION_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- REGION_MERGES_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for merges.
- REGION_NAMES_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- REGION_PLANS_THRESHOLD_PER_BALANCER - Static variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
-
- REGION_REPLICA_HOST_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaHostCostFunction
-
- REGION_REPLICA_RACK_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.RegionReplicaRackCostFunction
-
- REGION_REPLICA_REPLICATION_CATALOG_CONF_KEY - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- REGION_REPLICA_REPLICATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Whether asynchronous WAL replication to the secondary region replicas is enabled or not.
- REGION_REPLICA_REPLICATION_PEER - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- REGION_REPLICA_STORE_FILE_REFRESH - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Enables or disables refreshing store files of secondary region replicas when the memory is
above the global memstore lower limit.
- REGION_REPLICA_STORE_FILE_REFRESH_MEMSTORE_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
The multiplier to use when we want to refresh a secondary region instead of flushing a primary
region.
- REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Whether or not the secondary region will wait for observing a flush / region open event from
the primary region via async wal replication before enabling read requests.
- REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
The number of region replicas for the table.
- REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- REGION_REPLICATION_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- REGION_REPORT_RETENTION_DURATION_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- REGION_REPORT_RETENTION_DURATION_KEY - Static variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- REGION_SEP - Static variable in class org.apache.hadoop.hbase.mob.MobFileName
-
- REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs class name of the peer cluster
- REGION_SERVER_FAMILY - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what region server implementation to use.
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs impl name of the peer cluster
- REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_REPORT - Static variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Minimum allowable time limit delta (in milliseconds) that can be enforced during scans.
- REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
RPC scheduler to use for the region server.
- REGION_SIZE_REPORTING_CHORE_DELAY_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SIZE_REPORTING_CHORE_DELAY_KEY - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SIZE_REPORTING_CHORE_PERIOD_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SIZE_REPORTING_CHORE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SIZE_REPORTING_CHORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- REGION_SIZE_REPORTING_CHORE_TIMEUNIT_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SIZE_REPORTING_CHORE_TIMEUNIT_KEY - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- REGION_SPLIT_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The max number of threads used for splitting storefiles in parallel during the region split
process.
- REGION_SPLITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for splits.
- REGION_STATE_STAMP_COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- REGION_STORAGE_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- REGION_TEMP_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Temporary subdirectory of the region directory used for compaction output.
- RegionAdminServiceCallable<T> - Class in org.apache.hadoop.hbase.client
-
Similar to RegionServerCallable but for the AdminService interface.
- RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- RegionAdminServiceCallable(ClusterConnection, RpcControllerFactory, HRegionLocation, TableName, byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- regionAggImpl - Variable in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
-
- regionAppend - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionAppendKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionBatchSize - Variable in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- RegionBoundariesInformation() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- regionClose(TRegion) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor
-
- regionClose(HRegionFileSystem) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- regionClose(SnapshotProtos.SnapshotRegionManifest.Builder) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- regionClosedAbnormally(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- regionClosedWithoutPersistingToMeta(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RegionCloseOperation(RemoteProcedureDispatcher.RemoteProcedure, RegionInfo, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionCloseOperation
-
- regionClosing(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RegionCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
Implements the coprocessor environment and runtime support for coprocessors loaded within a
Region
.
- RegionCoprocessorHost(HRegion, RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Constructor
- RegionCoprocessorHost.BulkLoadObserverOperation - Class in org.apache.hadoop.hbase.regionserver
-
- RegionCoprocessorHost.RegionEnvironment - Class in org.apache.hadoop.hbase.regionserver
-
Encapsulation of the environment of each coprocessor
- RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors - Class in org.apache.hadoop.hbase.regionserver
-
Special version of RegionEnvironment that exposes RegionServerServices for Core Coprocessors
only.
- RegionCoprocessorHost.RegionObserverOperationWithoutResult - Class in org.apache.hadoop.hbase.regionserver
-
- RegionCoprocessorHost.TableCoprocessorAttribute - Class in org.apache.hadoop.hbase.regionserver
-
- RegionCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.client
-
Provides clients with an RPC connection to call Coprocessor Endpoint
Service
s against a given table region.
- RegionCoprocessorRpcChannel(ClusterConnection, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
Constructor
- RegionCoprocessorRpcChannelImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of a region based coprocessor rpc channel.
- RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl, TableName, RegionInfo, byte[], long, long) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- RegionCoprocessorService(CoprocessorService) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionCoprocessorService
-
Deprecated.
- RegionCoprocessorServiceExec - Class in org.apache.hadoop.hbase.client
-
Represents a coprocessor service method execution against a single region.
- RegionCoprocessorServiceExec(byte[], byte[], Descriptors.MethodDescriptor, Message) - Constructor for class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- regionCount - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- regionCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- 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.
- RegionCountSkewCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- regionDegreeLocalityMapping - Variable in class org.apache.hadoop.hbase.util.FSRegionScanner
-
Maps region encoded names to maps of hostnames to fractional locality of that region on that
host.
- regionDelete - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionDeleteKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- RegionDetails(ServerName, TableName, RegionMetrics) - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- RegionDetailsSerializer() - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetailsSerializer
-
- regionDir - Variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- regionDir - Variable in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker.RegionDirChecker
-
- regionDir - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntry
-
- RegionDirChecker(Path) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker.RegionDirChecker
-
- RegionDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- regionDirModTime - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntry
-
- regionDirName - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- regionDirName(String) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- regionDirName() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- regionDurability - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- regionEditsWrittenMap - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
-
- regionEditsWrittenMap - Variable in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
-
- RegionEntryBuffer(TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
-
- regionEnv - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
defined only for Endpoint implementation, so it can have way to access region services
- RegionEnvironment(RegionCoprocessor, int, int, Configuration, Region, RegionServerServices, ConcurrentMap<String, Object>) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
Constructor
- RegionEnvironmentForCoreCoprocessors(RegionCoprocessor, int, int, Configuration, Region, RegionServerServices, ConcurrentMap<String, Object>) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors
-
- RegionException - Exception in org.apache.hadoop.hbase
-
Thrown when something happens related to region handling.
- RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
-
default constructor
- RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
-
Constructor
- RegionExclusiveLock() - Constructor for class org.apache.hadoop.hbase.master.locking.LockProcedure.RegionExclusiveLock
-
- regionExhausted(Result[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- regionFailedOpen(RegionStateNode, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- regionFailedOpen - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- RegionFailedOpen(RegionStateNode) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- regionFavoredNodesMap - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Map of encoded region names to the DataNode locations they should be hosted on We store the
value as Address since InetSocketAddress is required by the HDFS API (create() that takes
favored nodes as hints for placing file blocks).
- regionFileSystem - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext.Builder
-
- regionFileSystem - Variable in class org.apache.hadoop.hbase.regionserver.StoreContext
-
- regionFinder - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionFinder - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- RegionFlushTask(HRegion, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure.RegionFlushTask
-
- regionFs - Variable in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure.StoreFileSplitter
-
- regionGet - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionGetKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- RegionGroupingProvider - Class in org.apache.hadoop.hbase.wal
-
A WAL Provider that returns a WAL per group of regions.
- RegionGroupingProvider() - Constructor for class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- RegionGroupingProvider.IdentityGroupingStrategy - Class in org.apache.hadoop.hbase.wal
-
- RegionGroupingProvider.RegionGroupingStrategy - Interface in org.apache.hadoop.hbase.wal
-
Map identifiers to a group number.
- RegionGroupingProvider.Strategies - Enum in org.apache.hadoop.hbase.wal
-
Maps between configuration names for strategies and implementation classes.
- regionId - Variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- regionId - Variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- regionId - Variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- regionIncrement - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionIncrementKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionIndexToEntityIndex(int) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
Maps region to the current entity (server or rack) on which it is stored
- regionIndexToEntityIndex(int) - Method in class org.apache.hadoop.hbase.master.balancer.RackLocalityCostFunction
-
- regionIndexToEntityIndex(int) - Method in class org.apache.hadoop.hbase.master.balancer.ServerLocalityCostFunction
-
- regionIndexToPrimaryIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionIndexToServerIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionIndexToTableIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionInfo - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.PutStatus
-
Deprecated.
- RegionInfo - Interface in org.apache.hadoop.hbase.client
-
Information about a region.
- regionInfo - Variable in class org.apache.hadoop.hbase.HRegionLocation
-
- regionInfo - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
Rpc target Region's RegionInfo we are going against.
- regionInfo - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- regionInfo - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- regionInfo - Variable in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- regionInfo - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- regionInfo - Variable in class org.apache.hadoop.hbase.master.normalizer.NormalizationTarget
-
- regionInfo - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOperation
-
- regionInfo - Variable in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- regionInfo - Variable in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- regionInfo - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- regionInfo - Variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- regionInfo - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- regionInfo - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.OnlineEntry
-
- REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The regioninfo column qualifier
- REGIONINFO_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The RegionInfo qualifier as a string
- RegionInfoBuilder - Class in org.apache.hadoop.hbase.client
-
- RegionInfoBuilder(TableName) - Constructor for class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- RegionInfoBuilder(RegionInfo) - Constructor for class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- RegionInfoComparator - Class in org.apache.hadoop.hbase.master.balancer
-
The following comparator assumes that RegionId from HRegionInfo can represent the age of the
region - larger RegionId means the region is younger.
- RegionInfoComparator() - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionInfoComparator
-
- RegionInfoDisplay - Class in org.apache.hadoop.hbase.client
-
Utility used composing RegionInfo for 'display'; e.g.
- RegionInfoDisplay() - Constructor for class org.apache.hadoop.hbase.client.RegionInfoDisplay
-
- regionInfoForFs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- regionInfoMap - Variable in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- regionInfoMap - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
This map contains the state of all hbck items.
- regionInfos - Variable in class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
- regionInfos - Variable in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- regionInTransition - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- RegionInTransitionChore(int) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionChore
-
- RegionInTransitionStat(Configuration) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- RegionLoad - Class in org.apache.hadoop.hbase
-
- RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- RegionLoad(RegionMetrics) - Constructor for class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
-
Deprecated.
- regionLoads - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- RegionLoadStats - Class in org.apache.hadoop.hbase.client
-
POJO representing region server load
- RegionLoadStats(int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RegionLoadStats
-
- RegionLocateType - Enum in org.apache.hadoop.hbase.client
-
Indicate which row you want to locate.
- RegionLocateType() - Constructor for enum org.apache.hadoop.hbase.client.RegionLocateType
-
- regionLocation - Variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- regionLocation - Variable in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- regionLocation - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- RegionLocationFinder - Class in org.apache.hadoop.hbase.master.balancer
-
This will find where data for a region is located in HDFS.
- RegionLocationFinder() - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- regionLocationFromHBase(HRegionLocation) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- regionLocations - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- RegionLocations - Class in org.apache.hadoop.hbase
-
Container for holding a list of
HRegionLocation
's that correspond to the same range.
- RegionLocations(HRegionLocation...) - Constructor for class org.apache.hadoop.hbase.RegionLocations
-
Constructs the region location list.
- RegionLocations(Collection<HRegionLocation>) - Constructor for class org.apache.hadoop.hbase.RegionLocations
-
- regionLocationsFromHBase(List<HRegionLocation>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- RegionLocationsFutureResult(CompletableFuture<RegionLocations>, RegionLocations, Throwable) - Constructor for class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.RegionLocationsFutureResult
-
- RegionLocator - Interface in org.apache.hadoop.hbase.client
-
Used to view region location information for a single HBase table.
- regionLocator - Variable in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- regionLocator - Variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2.TableInfo
-
- regionLocator - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- regionLock(List<RegionInfo>, String, Abortable) - Method in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.
- regionLock(List<RegionInfo>, String, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- regionLock(List<RegionInfo>, String, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Master based locks on namespaces/tables/regions.
- regionLockHolders - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- regionLocks - Variable in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- regionManifests - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- regionMap - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- regionMaximumEditLogSeqNum - Variable in class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
-
- regionMaxSeqIdInStores - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- RegionMetaLoadingVisitor() - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionMetaLoadingVisitor
-
- regionMeterName(String) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- regionMetricRegisterAndMark(Row) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- regionMetrics - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- RegionMetrics - Interface in org.apache.hadoop.hbase
-
Encapsulates per-region load metrics.
- RegionMetricsBuilder - Class in org.apache.hadoop.hbase
-
- RegionMetricsBuilder(byte[]) - Constructor for class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- RegionMetricsBuilder.RegionMetricsImpl - Class in org.apache.hadoop.hbase
-
- RegionMetricsImpl(byte[], int, int, int, int, long, long, Size, Size, Size, Size, Size, Size, Size, long, long, long, long, Map<byte[], Long>, float, long, float, long, long, long, CompactionState) - Constructor for class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- regionMetricsLossyCounting - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- regionMetricsUpdateTask - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- regionModeStrategy - Variable in class org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
-
- RegionModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
- RegionModeStrategy() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- regionModeStrategy - Variable in class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
-
- regionModeStrategy - Variable in class org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
-
- RegionMonitor(Connection, String[], boolean, CanaryTool.Sink, ExecutorService, boolean, TableName, boolean, HashMap<String, Long>, long, long) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.CostFromRegionLoadFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.LocalityBasedCostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.PrimaryRegionCountSkewCostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.RegionCountSkewCostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaHostCostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaRackCostFunction
-
- regionMoved(int, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.TableSkewCostFunction
-
- RegionMovedException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionMovedException(ServerName, long) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- RegionMovedException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
For hadoop.ipc internal call.
- RegionMover - Class in org.apache.hadoop.hbase.util
-
Tool for loading/unloading regions to/from given regionserver This tool can be run from Command
line directly as a utility.
- RegionMover(RegionMover.RegionMoverBuilder) - Constructor for class org.apache.hadoop.hbase.util.RegionMover
-
- RegionMover() - Constructor for class org.apache.hadoop.hbase.util.RegionMover
-
- RegionMover.RegionMoverBuilder - Class in org.apache.hadoop.hbase.util
-
Builder for Region mover.
- RegionMoverBuilder(String) - Constructor for class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- RegionMoverBuilder(String, Configuration) - Constructor for class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
-
- regionName - Variable in class org.apache.hadoop.hbase.client.FlushRegionCallable
-
- regionName - Variable in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- regionName - Variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- regionName - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- regionName - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- regionName - Variable in class org.apache.hadoop.hbase.client.SlowLogParams
-
- regionName - Variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- regionName - Variable in class org.apache.hadoop.hbase.mob.MobFileName
-
- regionName - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
-
- regionName - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- regionName - Variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
-
- regionName - Variable in class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- regionName - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- regionNamePrefix - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionNamePrefix1 - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionNamePrefix2 - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionNames - Variable in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- regionNamesToString(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- regionNameToRegionInfoMap - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
the region name to region info map
- regionNode - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- RegionNormalizer - Interface in org.apache.hadoop.hbase.master.normalizer
-
Performs "normalization" of regions of a table, making sure that suboptimal choice of split keys
doesn't leave cluster in a situation when some regions are substantially larger than others for
considerable amount of time.
- regionNormalizer - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- RegionNormalizerChore - Class in org.apache.hadoop.hbase.master.normalizer
-
- RegionNormalizerChore(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
-
- regionNormalizerChore - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- RegionNormalizerFactory - Class in org.apache.hadoop.hbase.master.normalizer
-
- RegionNormalizerFactory() - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerFactory
-
- regionNormalizerManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RegionNormalizerManager - Class in org.apache.hadoop.hbase.master.normalizer
-
- RegionNormalizerManager(RegionNormalizerTracker, RegionNormalizerChore, RegionNormalizerWorkQueue<TableName>, RegionNormalizerWorker) - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- regionNormalizerTracker - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- RegionNormalizerTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks region normalizer state up in ZK
- RegionNormalizerTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
-
- RegionNormalizerWorker - Class in org.apache.hadoop.hbase.master.normalizer
-
- RegionNormalizerWorker(Configuration, MasterServices, RegionNormalizer, RegionNormalizerWorkQueue<TableName>) - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- RegionNormalizerWorkQueue<E> - Class in org.apache.hadoop.hbase.master.normalizer
-
- RegionNormalizerWorkQueue() - Constructor for class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
- regionNormalizerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Coprocessors implement this interface to observe and mediate client actions on the region.
- RegionObserver.MutationType - Enum in org.apache.hadoop.hbase.coprocessor
-
Mutation type for postMutationBeforeWAL hook
- regionObserverGetter - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- RegionObserverOperationWithoutResult() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionObserverOperationWithoutResult
-
- RegionObserverOperationWithoutResult(User) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionObserverOperationWithoutResult
-
- RegionObserverOperationWithoutResult(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionObserverOperationWithoutResult
-
- RegionObserverOperationWithoutResult(User, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionObserverOperationWithoutResult
-
- regionOffline - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Regions marked as offline on a read of hbase:meta.
- regionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- regionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- regionOffline(RegionInfo) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as offline at balancer.
- regionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- RegionOfflineException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a table can not be located
- RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
default constructor
- RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
- regionOnline(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- regionOnline(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- regionOnline(RegionInfo, ServerName) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Marks the region as online at balancer.
- regionOnline(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- regionOpen(RegionInfo) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor
-
- regionOpen(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- regionOpen(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- regionOpenedWithoutPersistingToMeta(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- regionOpenedWithoutPersistingToMeta(AssignmentManager, RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- regionOpening(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RegionOpeningException - Exception in org.apache.hadoop.hbase.exceptions
-
Subclass if the server knows the region is now on another server.
- RegionOpeningException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
-
- RegionOpenOperation(RemoteProcedureDispatcher.RemoteProcedure, RegionInfo, long) - Constructor for class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOpenOperation
-
- RegionOperation(RemoteProcedureDispatcher.RemoteProcedure, RegionInfo, long) - Constructor for class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOperation
-
- regionPath - Variable in class org.apache.hadoop.hbase.util.FSRegionScanner
-
- RegionPlacementMaintainer - Class in org.apache.hadoop.hbase.master
-
A tool that is used for manipulating and viewing favored nodes information for regions.
- RegionPlacementMaintainer(Configuration) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- RegionPlacementMaintainer(Configuration, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- RegionPlacementMaintainer.RandomizedMatrix - Class in org.apache.hadoop.hbase.master
-
Some algorithms for solving the assignment problem may traverse workers or jobs in linear order
which may result in skewing the assignments of the first jobs in the matrix toward the last
workers in the matrix if the costs are uniform.
- RegionPlan - Class in org.apache.hadoop.hbase.master
-
Stores the plan for the move of an individual region.
- RegionPlan(RegionInfo, ServerName, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionPlan
-
Instantiate a plan for a region move, moving the specified region from the specified source
server to the specified destination server.
- RegionPlan.RegionPlanComparator - Class in org.apache.hadoop.hbase.master
-
- RegionPlanComparator() - Constructor for class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
-
- regionPlans - Variable in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- regionPlans - Variable in class org.apache.hadoop.hbase.client.BalancerDecision
-
- RegionProcedureStore - Class in org.apache.hadoop.hbase.procedure2.store.region
-
A procedure store which uses the master local store to store all the procedures.
- RegionProcedureStore(Server, MasterRegion, LeaseRecovery) - Constructor for class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- regionPut - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionPutKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- RegionRemoteProcedureBase - Class in org.apache.hadoop.hbase.master.assignment
-
The base class for the remote procedures used to open/close a region.
- RegionRemoteProcedureBase() - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- RegionRemoteProcedureBase(TransitRegionStateProcedure, RegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- RegionReplicaCandidateGenerator - Class in org.apache.hadoop.hbase.master.balancer
-
Generates candidates which moves the replicas out of the region server for co-hosted region
replicas
- RegionReplicaCandidateGenerator() - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionReplicaCandidateGenerator
-
- RegionReplicaFlushHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
HBASE-11580: With the async wal approach (HBASE-11568), the edits are not persisted to WAL in
secondary region replicas.
- RegionReplicaFlushHandler(Server, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, int, HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- RegionReplicaGroupingCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
A cost function for region replicas.
- RegionReplicaGroupingCostFunction() - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionReplicaGroupingCostFunction
-
- RegionReplicaHostCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
A cost function for region replicas.
- RegionReplicaHostCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionReplicaHostCostFunction
-
- regionReplicaHostCostFunction - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- RegionReplicaInfo - Class in org.apache.hadoop.hbase.master.http
-
A POJO that consolidates the information about a single region replica that's stored in meta.
- RegionReplicaInfo(Result, HRegionLocation) - Constructor for class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- RegionReplicaOutputSink(WALSplitter.PipelineController, TableDescriptors, EntryBuffers, ClusterConnection, ExecutorService, int, int) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- RegionReplicaRackCandidateGenerator - Class in org.apache.hadoop.hbase.master.balancer
-
Generates candidates which moves the replicas out of the rack for co-hosted region replicas in
the same rack
- RegionReplicaRackCandidateGenerator() - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionReplicaRackCandidateGenerator
-
- RegionReplicaRackCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
A cost function for region replicas for the rack distribution.
- RegionReplicaRackCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.RegionReplicaRackCostFunction
-
- regionReplicaRackCostFunction - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- RegionReplicaReplayCallable(ClusterConnection, RpcControllerFactory, TableName, HRegionLocation, RegionInfo, byte[], List<WAL.Entry>, AtomicLong) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable
-
- RegionReplicaReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
-
A
ReplicationEndpoint
endpoint which receives the WAL
edits from the WAL, and sends the edits to replicas of regions.
- RegionReplicaReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- RegionReplicaReplicationEndpoint.RegionReplicaOutputSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
- RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable - Class in org.apache.hadoop.hbase.replication.regionserver
-
Calls replay on the passed edits for the given set of entries belonging to the region.
- RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter - Class in org.apache.hadoop.hbase.replication.regionserver
-
- RegionReplicaReplicationEndpoint.RetryingRpcCallable<V> - Class in org.apache.hadoop.hbase.replication.regionserver
-
- RegionReplicaSinkWriter(RegionReplicaReplicationEndpoint.RegionReplicaOutputSink, ClusterConnection, ExecutorService, int, TableDescriptors) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- regionReplication - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- RegionReplicaUtil - Class in org.apache.hadoop.hbase.client
-
Utility methods which contain the logic for regions and replicas.
- RegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- regionReportLifetimeMillis - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- RegionRequest(HRegionLocation) - Constructor for class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.RegionRequest
-
- RegionResult() - Constructor for class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- regions - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- regions - Variable in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- regions - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regions - Variable in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- regions - Variable in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- regions - Variable in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- regions - Variable in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- regions - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- regions - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- regions - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- regions - Variable in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- REGIONS_RECOVERY_CHORE_NAME - Static variable in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
- REGIONS_RECOVERY_INTERVAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGIONS_SCANNED_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- regionScan - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- regionScanKey - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
-
RegionScanner describes iterators over rows in an HRegion.
- RegionScannerAsResultScanner - Class in org.apache.hadoop.hbase.master.region
-
- RegionScannerAsResultScanner(RegionScanner) - Constructor for class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- RegionScannerCloseCallBack(RegionScanner) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerCloseCallBack
-
- RegionScannerHolder(RegionScanner, HRegion, RpcCallback, RpcCallback, boolean, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- RegionScannerImpl - Class in org.apache.hadoop.hbase.regionserver
-
RegionScannerImpl is used to combine scanners from multiple Stores (aka column families).
- RegionScannerImpl(Scan, List<KeyValueScanner>, HRegion, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- RegionScannersCloseCallBack() - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
-
- RegionScannerShippedCallBack(String, Shipper, LeaseManager.Lease) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerShippedCallBack
-
- regionServer - Variable in class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- regionServer - Variable in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- regionServer - Variable in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
region server process name
- regionServer - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- regionServer - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- regionServer - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- regionServer - Variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- regionServer - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- regionServer - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- regionServer - Variable in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
- REGIONSERVER_ADMIN_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Services launched in RSRpcServices.
- REGIONSERVER_CLIENT_META_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- REGIONSERVER_CLIENT_SERVICE_CONFIG - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- REGIONSERVER_CODEC - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
regionserver codec list
- REGIONSERVER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
A configuration key for regionserver info port
- REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
-
A flag that enables automatic selection of regionserver info port
- REGIONSERVER_KRB_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
- REGIONSERVER_KRB_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.security.SecurityConstants
-
- REGIONSERVER_META_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
Whether all storefiles should be refreshed, as opposed to just hbase:meta's Meta region doesn't
have WAL replication for replicas enabled yet
- REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The period (in milliseconds) between computing region server point in time metrics
- REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port region server listens on.
- REGIONSERVER_PROCEDURE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- REGIONSERVER_STOREFILE_REFRESH_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
The period (in milliseconds) for refreshing the store files for the secondary regions.
- RegionServerAbortedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is aborting.
- RegionServerAbortedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
-
- regionServerAccounting - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- regionServerAccounting - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- RegionServerAccounting - Class in org.apache.hadoop.hbase.regionserver
-
RegionServerAccounting keeps record of some basic real time information about the Region Server.
- RegionServerAccounting(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- regionServerAddressTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cache for all the region servers in the cluster.
- RegionServerAddressTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Class for tracking the region servers for a cluster.
- RegionServerAddressTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionServerAddressTracker
-
- RegionServerCallable<T,S> - Class in org.apache.hadoop.hbase.client
-
Implementations make a RPC call against a RegionService via a protobuf Service.
- RegionServerCallable(Connection, TableName, byte[], RpcController) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
-
- RegionServerCallable(Connection, TableName, byte[], RpcController, int) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCallable
-
- regionServerClass - Variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- regionServerClass - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- RegionServerCoprocessor - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionServerCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionServerCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerCoprocessorHost(RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- RegionServerCoprocessorHost.RegionServerEnvironment - Class in org.apache.hadoop.hbase.regionserver
-
Coprocessor environment extension providing access to region server related services.
- RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors - Class in org.apache.hadoop.hbase.regionserver
-
Special version of RegionServerEnvironment that exposes RegionServerServices for Core
Coprocessors only.
- RegionServerCoprocessorHost.RegionServerObserverOperation - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerCoprocessorRpcChannelImpl - Class in org.apache.hadoop.hbase.client
-
The implementation of a region server based coprocessor rpc channel.
- RegionServerCoprocessorRpcChannelImpl(AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder<Message>) - Constructor for class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
-
- RegionServerCoprocessorService(SingletonCoprocessorService) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionServerCoprocessorService
-
Deprecated.
- RegionServerEnvironment(RegionServerCoprocessor, int, int, Configuration, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- RegionServerEnvironmentForCoreCoprocessors(RegionServerCoprocessor, int, int, Configuration, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors
-
- RegionServerFlushTableProcedureManager - Class in org.apache.hadoop.hbase.procedure.flush
-
This manager class handles flushing of the regions for table on a
HRegionServer
.
- RegionServerFlushTableProcedureManager(Configuration, HRegionServer, ProcedureMemberRpcs, ProcedureMember) - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Exposed for testing.
- RegionServerFlushTableProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- RegionServerFlushTableProcedureManager.FlushTableSubprocedureBuilder - Class in org.apache.hadoop.hbase.procedure.flush
-
- RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool - Class in org.apache.hadoop.hbase.procedure.flush
-
We use the FlushTableSubprocedurePool, a class specific thread pool instead of
ExecutorService
.
- regionServerHostname - Variable in class org.apache.hadoop.hbase.master.http.MasterRedirectServlet
-
- regionServerInfoPort - Variable in class org.apache.hadoop.hbase.master.http.MasterRedirectServlet
-
- regionServerLimiter - Variable in class org.apache.hadoop.hbase.quotas.ExceedOperationQuota
-
- RegionServerList - Interface in org.apache.hadoop.hbase.master
-
For storing the region server list.
- regionServerListNode - Variable in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
-
- regionServerLocks - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- RegionServerMetricsWrapperRunnable() - Constructor for class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionServerMetricsWrapperRunnable
-
- regionServerMode - Variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
True if we are to run in 'regionServer' mode.
- RegionServerModeStrategy - Class in org.apache.hadoop.hbase.hbtop.mode
-
- RegionServerModeStrategy() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
-
- RegionServerMonitor(Connection, String[], boolean, CanaryTool.Sink, ExecutorService, boolean, boolean, long) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines coprocessor hooks for interacting with operations on the
HRegionServer
process.
- RegionServerObserverOperation() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerObserverOperation
-
- RegionServerObserverOperation(User) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerObserverOperation
-
- RegionServerProcedureManager - Class in org.apache.hadoop.hbase.procedure
-
A life-cycle management interface for globally barriered procedures on region servers.
- RegionServerProcedureManager() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
- RegionServerProcedureManagerHost - Class in org.apache.hadoop.hbase.procedure
-
Provides the globally barriered procedure framework and environment for region server oriented
operations.
- RegionServerProcedureManagerHost() - Constructor for class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- regionServerQuotaCache - Variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- regionServerRegex - Variable in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- RegionServerRegistry - Class in org.apache.hadoop.hbase.client
-
Connection registry implementation for region server.
- RegionServerRegistry(HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.RegionServerRegistry
-
- regionServerRemote - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- regionServerRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationListener
-
A region server has been removed from the local cluster
- regionServerReport(RpcController, RegionServerStatusProtos.RegionServerReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- regionServerReport(ServerName, ServerMetrics) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- RegionServerRpcQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
Region Server Quota Manager.
- RegionServerRpcQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- RegionServerRunningException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if the region server log directory exists (which indicates another region server is
running at the same address)
- RegionServerRunningException() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Default Constructor
- RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Constructs the exception and supplies a string as the message
- regionServers - Variable in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- regionServers - Variable in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- regionServers - Variable in class org.apache.hadoop.hbase.zookeeper.RegionServerAddressTracker
-
- regionServerServices - Variable in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
- regionServerServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironmentForCoreCoprocessors
-
- RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
-
- RegionServerServices.PostOpenDeployContext - Class in org.apache.hadoop.hbase.regionserver
-
Context for postOpenDeployTasks().
- RegionServerServices.RegionStateTransitionContext - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerSnapshotManager - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
This manager class handles the work dealing with snapshots for a
HRegionServer
.
- RegionServerSnapshotManager(Configuration, HRegionServer, ProcedureMemberRpcs, ProcedureMember) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Exposed for testing.
- RegionServerSnapshotManager() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- RegionServerSnapshotManager.SnapshotSubprocedureBuilder - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
Build the actual snapshot runner that will do all the 'hard' work
- RegionServerSnapshotManager.SnapshotSubprocedurePool - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
We use the SnapshotSubprocedurePool, a class specific thread pool instead of
ExecutorService
.
- RegionServerSpaceQuotaManager - Class in org.apache.hadoop.hbase.quotas
-
A manager for filesystem space quotas in the RegionServer.
- RegionServerSpaceQuotaManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- RegionServerSpaceQuotaManager(RegionServerServices, SpaceViolationPolicyEnforcementFactory) - Constructor for class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- regionServerStartup(RpcController, RegionServerStatusProtos.RegionServerStartupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- regionServerStartup(RegionServerStatusProtos.RegionServerStartupRequest, int, String, InetAddress) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Let the server manager know a new regionserver has come online
- RegionServerStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerStdOutSink
-
- RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is in shutting down state.
- RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
-
- RegionServerTableMetrics - Class in org.apache.hadoop.hbase.regionserver
-
Captures operation metrics by table.
- RegionServerTableMetrics(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerTableMetrics
-
- RegionServerTask(Connection, String, RegionInfo, CanaryTool.RegionServerStdOutSink, AtomicLong) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- RegionServerThread(HRegionServer, int) - Constructor for class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
- regionServerToRackMap - Variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- regionServerTracker - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RegionServerTracker - Class in org.apache.hadoop.hbase.master
-
Tracks the online region servers via ZK.
- RegionServerTracker(ZKWatcher, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.RegionServerTracker
-
- regionServerWrapper - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- regionServices - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- regionServicesForStores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- RegionServicesForStores - Class in org.apache.hadoop.hbase.regionserver
-
Services a Store needs from a Region.
- RegionServicesForStores(HRegion, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- regionsFromMeta - Variable in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- regionsIncluded - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- regionsInQueue - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- regionsInTransition - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- regionsInTransition - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- regionsInTransition - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- regionsInTransition - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- regionsInTransitionInRS - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
A map from RegionName to current action in progress.
- RegionSize - Interface in org.apache.hadoop.hbase.quotas
-
Interface that encapsulates optionally sending a Region's size to the master.
- RegionSizeCalculator - Class in org.apache.hadoop.hbase.mapreduce
-
Computes size of each region for given table and given column families.
- RegionSizeCalculator(RegionLocator, Admin) - Constructor for class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
Computes size of each region for table and given column families.
- regionSizeCalculator - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Used to generate splits based on region size.
- RegionSizeImpl - Class in org.apache.hadoop.hbase.quotas
-
An object encapsulating a Region's size and whether it's been reported to the master since the
value last changed.
- RegionSizeImpl(long) - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeImpl
-
- regionSizeMb - Variable in class org.apache.hadoop.hbase.master.normalizer.NormalizationTarget
-
- regionSizeReportCounter - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- regionSizeReporter - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- RegionSizeReportingChore - Class in org.apache.hadoop.hbase.quotas
-
A Chore which sends the region size reports on this RegionServer to the Master.
- RegionSizeReportingChore(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- regionSizeReportingChoreTimer - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- regionSizes - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- regionSizeStore - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- RegionSizeStore - Interface in org.apache.hadoop.hbase.quotas
-
An interface for concurrently storing and updating the size of a Region.
- RegionSizeStoreFactory - Class in org.apache.hadoop.hbase.quotas
-
- RegionSizeStoreFactory() - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
-
- RegionSizeStoreImpl - Class in org.apache.hadoop.hbase.quotas
-
- RegionSizeStoreImpl() - Constructor for class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- regionsLowerLimit - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- regionsMap - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
RegionName -- i.e.
- regionsMap - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RegionSnapshotTask(HRegion, SnapshotProtos.SnapshotDescription, boolean, ForeignExceptionDispatcher) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- regionsOnCrashedServer - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Regions that were on the crashed server.
- regionSources - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- regionSpaceReportsGauge - Variable in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- regionsPerHost - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionsPerRack - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionsPerServer - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- RegionSplitCalculator<R extends KeyRange> - Class in org.apache.hadoop.hbase.util
-
This is a generic region split calculator.
- RegionSplitCalculator(Comparator<R>) - Constructor for class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- regionSplitLimit - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Splitting should not take place if the total number of regions exceed this.
- RegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A split policy determines when a Region should be split.
- RegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- RegionSplitRestriction - Class in org.apache.hadoop.hbase.regionserver
-
A split restriction that restricts the pattern of the split point.
- RegionSplitRestriction() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
- RegionSplitter - Class in org.apache.hadoop.hbase.util
-
The
RegionSplitter
class provides several utilities to help in the administration
lifecycle for developers who choose to manually split regions instead of having HBase handle that
automatically.
- RegionSplitter() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter
-
- RegionSplitter.DecimalStringSplit - Class in org.apache.hadoop.hbase.util
-
The format of a DecimalStringSplit region boundary is the ASCII representation of reversed
sequential number, or any other uniformly distributed decimal value.
- RegionSplitter.HexStringSplit - Class in org.apache.hadoop.hbase.util
-
- RegionSplitter.NumberStringSplit - Class in org.apache.hadoop.hbase.util
-
- RegionSplitter.SplitAlgorithm - Interface in org.apache.hadoop.hbase.util
-
A generic interface for the RegionSplitter code to use for all it's functionality.
- RegionSplitter.UniformSplit - Class in org.apache.hadoop.hbase.util
-
A SplitAlgorithm that divides the space of possible keys evenly.
- regionsRecoveryChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RegionsRecoveryChore - Class in org.apache.hadoop.hbase.master
-
This chore, every time it runs, will try to recover regions with high store ref count by
reopening them
- RegionsRecoveryChore(Stoppable, Configuration, HMaster) - Constructor for class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
Construct RegionsRecoveryChore with provided params
- regionsRecoveryConfigManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RegionsRecoveryConfigManager - Class in org.apache.hadoop.hbase.master
-
Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
- RegionsRecoveryConfigManager(HMaster) - Constructor for class org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
-
- RegionsResource - Class in org.apache.hadoop.hbase.rest
-
- RegionsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.RegionsResource
-
Constructor nn
- regionState - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- RegionState - Class in org.apache.hadoop.hbase.master
-
State of a Region while undergoing transitions.
- RegionState(RegionInfo, RegionState.State, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState(RegionInfo, RegionState.State, long, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState(RegionInfo, RegionState.State, long, ServerName, long) - Constructor for class org.apache.hadoop.hbase.master.RegionState
-
- RegionState.State - Enum in org.apache.hadoop.hbase.master
-
- RegionStateListener - Interface in org.apache.hadoop.hbase
-
The listener interface for receiving region state events.
- RegionStateNode - Class in org.apache.hadoop.hbase.master.assignment
-
Current Region State.
- RegionStateNode(RegionInfo, ConcurrentMap<RegionInfo, RegionStateNode>) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- RegionStateNode.AssignmentProcedureEvent - Class in org.apache.hadoop.hbase.master.assignment
-
- regionStates - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RegionStates - Class in org.apache.hadoop.hbase.master.assignment
-
RegionStates contains a set of Maps that describes the in-memory state of the AM, with the
regions available in the system, the region in transition, the offline regions and the servers
holding regions.
- RegionStates() - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- regionStates - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
-
- RegionStates.RegionFailedOpen - Class in org.apache.hadoop.hbase.master.assignment
-
- RegionStates.RegionStateStampComparator - Class in org.apache.hadoop.hbase.master.assignment
-
- RegionStatesCount - Class in org.apache.hadoop.hbase.client
-
- RegionStatesCount() - Constructor for class org.apache.hadoop.hbase.client.RegionStatesCount
-
- RegionStatesCount.RegionStatesCountBuilder - Class in org.apache.hadoop.hbase.client
-
- RegionStatesCountBuilder() - Constructor for class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- RegionStateStampComparator() - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateStampComparator
-
- regionStateStore - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RegionStateStore - Class in org.apache.hadoop.hbase.master.assignment
-
Store Region State to hbase:meta table.
- RegionStateStore(MasterServices, MasterRegion) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- RegionStateStore.RegionStateVisitor - Interface in org.apache.hadoop.hbase.master.assignment
-
- RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, RegionInfo...) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long, long, RegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- RegionStats(MetricRegistry, String) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
-
- regionStatsEnabled - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- regionStatus - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- regionStatus - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- RegionStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- regionsToAdd - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- regionsToAdd - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- regionsToIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionsToMerge - Variable in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Two or more regions to merge, the 'merge parents'.
- regionsToMostLocalEntities - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- regionsToRemove - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- regionsToRemove - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- regionsToRestore - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- regionsToRestore - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- regionsUpperLimit - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- regionsWithoutValidFavoredNodes - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- regionsZNode - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- RegionTask(Connection, RegionInfo, ServerName, CanaryTool.RegionStdOutSink, CanaryTool.RegionTask.TaskType, boolean, LongAdder, boolean) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- RegionTaskResult(RegionInfo, TableName, ServerName, ColumnFamilyDescriptor) - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- regionThreads - Variable in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- regionToBestLocalityRSMapping - Variable in class org.apache.hadoop.hbase.util.FSRegionScanner
-
Maps each region to the RS with highest locality for that region.
- RegionTooBusyException - Exception in org.apache.hadoop.hbase
-
Thrown by a region server if it will block and wait to serve a request.
- RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
-
- regionToRegionServerMap - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
the region to region server map
- RegionTransitionProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
- RegionTransitionProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- RegionTransitionProcedure(RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- regionUsage - Variable in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- regionUsage - Variable in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- RegionVisualizer - Class in org.apache.hadoop.hbase.master.http
-
Support class for the "Region Visualizer" rendered out of
src/main/jamon/org/apache/hadoop/hbase/tmpl/master/RegionVisualizerTmpl.jamon
- RegionVisualizer() - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- RegionVisualizer(Admin) - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- RegionVisualizer(AsyncAdmin) - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- RegionVisualizer.ByteArraySerializer - Class in org.apache.hadoop.hbase.master.http
-
- RegionVisualizer.RegionDetails - Class in org.apache.hadoop.hbase.master.http
-
POJO carrying detailed information about a region for use in visualizations.
- RegionVisualizer.RegionDetailsSerializer - Class in org.apache.hadoop.hbase.master.http
-
- RegionVisualizer.SizeAsBytesSerializer - Class in org.apache.hadoop.hbase.master.http
-
Simplify representation of a
Size
instance by converting to bytes.
- regionWalDir - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- regionWrapper - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- regionWrapper - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- register() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
registration of ChaosAgent by checking and creating necessary ZNodes.
- register(SocketChannel) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- register(String, Metric) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- register(String, Gauge<T>) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- register(String, String, Object) - Method in interface org.apache.hadoop.hbase.metrics.MBeanSource
-
Register an mbean with the underlying metrics system
- register(String, String, Object) - Method in class org.apache.hadoop.hbase.metrics.MBeanSourceImpl
-
Register an mbean with the underlying metrics system
- register(String, Gauge<T>) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
- register(String, Metric) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Registers the
Metric
with the given name if there does not exist one with the same
name.
- register(E) - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- register(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
Register a MetricsRegionSource as being open.
- register(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- register(MetricsUserSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
-
- register() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsUserSource
-
- register() - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- registerAll(MetricSet) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- registerAll(MetricSet) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Registers the
Metric
s in the given MetricSet.
- registerAndMarkMeter(String) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- registerAndMarkMetrics(ObserverContext<RegionCoprocessorEnvironment>, Row) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.ExampleRegionObserverMeta
-
- registerChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Needs to be called to register the children to the manager.
- registerChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Needs to be called to register the children to the manager.
- registerConfigurationObservers() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- registerConfigurationObservers() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- registerCustomFilter(Configuration) - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- registerDeserializer(CacheableDeserializer<Cacheable>) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Register the given
Cacheable
-- usually an hfileblock instance, these implement the
Cacheable Interface -- deserializer and generate a unique identifier id for it and return this
as our result.
- registeredDeserializers - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
- registeredSources - Variable in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
- registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- registerFlushRequestListener(FlushRequestListener) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Register a FlushRequestListener n
- registerFlushRequestListener(FlushRequestListener) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Register a MemstoreFlushListener n
- registerForWrite(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
Add a connection to the list that want to write,
- registerListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
set the listener for task changes.
- registerListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- registerListener(ServerListener) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Add the listener to the notification list.
- registerListener(ProcedureExecutor.ProcedureExecutorListener) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- registerListener(ProcedureStore.ProcedureStoreListener) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Add the listener to the notification list.
- registerListener(ProcedureStore.ProcedureStoreListener) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- registerListener(ZKListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Register the specified listener to receive ZooKeeper events.
- registerListenerFirst(ZKListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Register the specified listener to receive ZooKeeper events and add it as the first in the list
of current listeners.
- registerMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
-
- registerMetrics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- registerNonce(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Register a nonce for a procedure that is going to be submitted.
- registerObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Register an observer class
- registerPeerConfigListener(ReplicationPeerConfigListener) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Register a peer config listener to catch the peer config change event.
- registerPeerConfigListener(ReplicationPeerConfigListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- registerRegion(RegionInfo, int, int, Map<String, Deque<BalancerRegionLoad>>, RegionLocationFinder) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Helper for Cluster constructor to handle a region
- registerService(Service) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- registerService(Service) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Registers a new protocol buffer Service
subclass as a master coprocessor endpoint.
- registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Registers a new protocol buffer Service
subclass as a coprocessor endpoint to be
available for handling Region#execService(com.google.protobuf.RpcController,
org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall) calls.
- registerService(Service) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- registerService(Service) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Registers a new protocol buffer Service
subclass as a coprocessor endpoint to be
available for handling
- registerTuneObserver(HeapMemoryManager.HeapMemoryTuneObserver) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- registerWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Registers WALActionsListener
- registerWrites() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
Take the list of the connections that want to write, and register them in the selector.
- registries - Variable in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- registry - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- registry - Variable in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- registry - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
Cluster registry of basic info such as clusterid and meta region location.
- registry - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- registry - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- registry - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter.Builder
-
- registry - Variable in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Note that there are at least 4 MetricRegistry definitions in the source code.
- registry - Variable in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter.MetricsSourceAdapter
-
- registry - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- registry - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- registry - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- registryEndpointRefresher - Variable in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- RegistryEndpointsRefresher - Class in org.apache.hadoop.hbase.client
-
- RegistryEndpointsRefresher(long, long, long, RegistryEndpointsRefresher.Refresher) - Constructor for class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- RegistryEndpointsRefresher.Refresher - Interface in org.apache.hadoop.hbase.client
-
- regroupResults(Result) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
-
- regularStores - Variable in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- reinit(Configuration) - Method in interface org.apache.hadoop.hbase.io.compress.CanReinit
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- reinit(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- reinitializeCellSet(int, KeyValueScanner, CellSet, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
-
- reinitializeCellSet(int, KeyValueScanner, CellSet, MemStoreSizing, MemStoreCompactionStrategy.Action) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
-
- reInitializeCompactionsExecutors() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- REJECT_BATCH_ROWS_OVER_THRESHOLD - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit.Rejection
-
- Rejection() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit.Rejection
-
- rejectRowsWithSizeOverThreshold - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- release(ConnectionImplementation.MasterServiceState) - Static method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- release() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- release() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
We've three cases to release refCnt now:
1.
- release() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Decrease its reference count, and if no reference then free the memory of this object, its
backend is usually a
ByteBuff
, and we will put its NIO
ByteBuffers back to
ByteBuffAllocator
- release() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
-
- release() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- release() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Releases resources used by this writer.
- release() - Method in class org.apache.hadoop.hbase.master.locking.LockManager.MasterLock
-
Release the lock.
- release(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- release() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
- release(int) - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
-
- release() - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- release(int) - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- release(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
Called by the ProcedureExecutor to mark the procedure step as finished.
- release() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- release() - Method in interface org.apache.hadoop.hbase.regionserver.Region.RowLock
-
Release the given lock.
- release() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- releaseBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- releaseBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Hooray!
- releaseByWAL() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- releaseCompaction(ServerName) - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- releasedBarrierLatch - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
latch for waiting until all members have executed and released their in barrier state
- releaseDelegationToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Releases a previously acquired delegation token.
- releasedLocalBarrier - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
counted down when the Subprocedure has completed
- releaseExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
Returns whether we should wake the procedures waiting on the lock here.
- releaseIfNotCurBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
The curBlock will be released by shipping or close method, so only need to consider releasing
the block, which was read from HFile before and not referenced by curBlock.
- releaseLatch(ProcedurePrepareLatch, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- releaseLatch() - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- releaseLock(MasterProcedureEnv) - Method in interface org.apache.hadoop.hbase.master.locking.LockProcedure.LockInterface
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.NamespaceExclusiveLock
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.RegionExclusiveLock
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableExclusiveLock
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableSharedLock
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- releaseLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- releaseLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The user should override this method, and release lock if necessary.
- releaseLock(Procedure<TEnvironment>, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- releaseLockEntry(IdLock.Entry) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Must be called in a finally block to decrease the internal counter and remove the monitor
object for the given id if the caller is the last client.
- releaseMaster(ConnectionImplementation.MasterServiceState) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- releaseResources() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
Release the resources it uses (The ByteBuffers) which are obtained from pool.
- releaseResources() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- Reset the interruption
indicator and clear the pointers in order to allow good garbage collection
- releaseRowLocks(List<Region.RowLock>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- releaseSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Called by Thread A when it is done with the work it needs to do while Thread B is halted.
- releaseSharedLock() - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
Returns whether we should wake the procedures waiting on the lock here.
- releaseSlot(ByteSlot) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- releaseSplitWALWorker(ServerName, MasterProcedureScheduler) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
After the worker finished the split WAL task, it will release the worker, and wake up all the
suspend procedures in the ProcedureEvent
- releaseSyncFuture(SyncFuture, long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
Release the passed syncFuture
- releaseSyncFutures(long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
Release all SyncFutures whose sequence is <= currentSequence
.
- releaseSyncLatch() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- releaseSyncLatch() - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- reload - Variable in class org.apache.hadoop.hbase.client.FlushRegionCallable
-
- reload(Configuration) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Reload configuration for the given algorithm.
- reloadConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- reloadZkWatcher() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Closes the current ZKW (if not null) and creates a new one
- relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Find the location of the region of tableName that row lives in, ignoring any
value that might be in the cache.
- relocateRegion(TableName, byte[], int) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Find the location of the region of tableName that row lives in, ignoring any
value that might be in the cache.
- relocateRegion(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- relocateRegion(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- relogin() - Method in class org.apache.hadoop.hbase.security.provider.GssSaslClientAuthenticationProvider
-
- relogin() - Method in interface org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProvider
-
Executes any necessary logic to re-login the client.
- RELOGIN_EXECUTOR - Static variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- reloginInProgress - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- reloginMaxBackoff - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- remainder - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- remaining - Variable in class org.apache.hadoop.hbase.ipc.BufferChain
-
- remaining() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns the number of elements between the current position and the limit.
- remaining() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns the number of elements between the current position and the limit.
- remaining() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- remaining - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.AggregatingCompleteTracker
-
- remainingCapacity() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- remainingCapacity() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- remainingCapacity() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- remainingResults - Variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- remainingTasksInCoordination() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Return the number of remaining tasks
- remainingTasksInCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- remainingTimeNs() - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- remainingTimeNs() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- remainingTimeNs() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- remote(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- REMOTE_CLUSTER_CONF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- REMOTE_CLUSTER_ZOOKEEPER_CLIENT_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- REMOTE_CLUSTER_ZOOKEEPER_QUORUM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- REMOTE_CLUSTER_ZOOKEEPER_ZNODE_PARENT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- REMOTE_DIR - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.Options
-
- REMOTE_LOCKS_TIMEOUT_MS_CONF - Static variable in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- REMOTE_RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- REMOTE_RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- remoteAddress - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- remoteCallBuild(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- remoteCallBuild(TEnv, TRemote) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
-
For building the remote operation.
- remoteCallFailed(MasterProcedureEnv, RegionStateNode, IOException) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- remoteCallFailed(MasterProcedureEnv, ServerName, IOException) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- remoteCallFailed(MasterProcedureEnv, RegionStateNode, IOException) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- remoteCallFailed(MasterProcedureEnv, ServerName, IOException) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- remoteCallFailed(MasterProcedureEnv, RegionStateNode, IOException) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
Returns If true, we will re-wake up this procedure; if false, the procedure stays suspended.
- remoteCallFailed(MasterProcedureEnv, IOException) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- remoteCallFailed(MasterProcedureEnv, ServerName, IOException) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- remoteCallFailed(TEnv, TRemote, IOException) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
-
Called when the executeProcedure call is failed.
- remoteDir - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- remoteDir - Variable in class org.apache.hadoop.hbase.util.DynamicClassLoader
-
- remoteDirFs - Variable in class org.apache.hadoop.hbase.util.DynamicClassLoader
-
- remoteDispatch(ServerName, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- remoteDispatch(TRemote, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- remoteDispatcher - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- remoteId - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- remoteId() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- remoteLocks - Variable in class org.apache.hadoop.hbase.master.locking.LockManager
-
- remoteLocks() - Method in class org.apache.hadoop.hbase.master.locking.LockManager
-
- RemoteLocks() - Constructor for class org.apache.hadoop.hbase.master.locking.LockManager.RemoteLocks
-
- RemoteOperation(RemoteProcedureDispatcher.RemoteProcedure) - Constructor for class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteOperation
-
- remoteOperationCompleted(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- remoteOperationCompleted(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- remoteOperationCompleted(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- remoteOperationCompleted(TEnv) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
-
Called when RS tells the remote procedure is succeeded through the
reportProcedureDone
method.
- remoteOperationDone(MasterProcedureEnv, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- remoteOperationFailed(MasterProcedureEnv, RemoteProcedureException) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- remoteOperationFailed(MasterProcedureEnv, RemoteProcedureException) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- remoteOperationFailed(MasterProcedureEnv, RemoteProcedureException) - Method in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- remoteOperationFailed(TEnv, RemoteProcedureException) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
-
Called when RS tells the remote procedure is failed through the reportProcedureDone
method.
- remotePort - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- remotePort - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- remoteProc - Variable in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- remoteProcedure - Variable in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteOperation
-
- remoteProcedureComplete(long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- remoteProcedureCompleted(long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- RemoteProcedureDispatcher<TEnv,TRemote extends Comparable<TRemote>> - Class in org.apache.hadoop.hbase.procedure2
-
A procedure dispatcher that aggregates and sends after elapsed time or after we hit count
threshold.
- RemoteProcedureDispatcher(Configuration) - Constructor for class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- RemoteProcedureDispatcher.BufferNode - Class in org.apache.hadoop.hbase.procedure2
-
Node that contains a set of RemoteProcedures
- RemoteProcedureDispatcher.DelayedTask - Class in org.apache.hadoop.hbase.procedure2
-
Delayed object that holds a FutureTask.
- RemoteProcedureDispatcher.RemoteNode<TEnv,TRemote> - Interface in org.apache.hadoop.hbase.procedure2
-
Account of what procedures are running on remote node.
- RemoteProcedureDispatcher.RemoteOperation - Class in org.apache.hadoop.hbase.procedure2
-
Data structure with reference to remote operation.
- RemoteProcedureDispatcher.RemoteProcedure<TEnv,TRemote> - Interface in org.apache.hadoop.hbase.procedure2
-
Remote procedure reference.
- RemoteProcedureDispatcher.TimeoutExecutorThread - Class in org.apache.hadoop.hbase.procedure2
-
- RemoteProcedureException - Exception in org.apache.hadoop.hbase.procedure2
-
A RemoteProcedureException is an exception from another thread or process.
- RemoteProcedureException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
Create a new RemoteProcedureException that can be serialized.
- remoteProcedureFailed(long, RemoteProcedureException) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- RemoteProcedureResultReporter - Class in org.apache.hadoop.hbase.regionserver
-
A thread which calls reportProcedureDone
to tell master the result of a remote procedure.
- RemoteProcedureResultReporter(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- remoteProcedures - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- RemoteUserIdentity(String, String) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHttpServlet.RemoteUserIdentity
-
- RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
-
A RemoteException
with some extra information.
- RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException(String, String, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException(String, String, String, int, boolean, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException.ClassLoaderHolder - Class in org.apache.hadoop.hbase.ipc
-
Dynamic class loader to load filter/comparators
- remove(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove all
Constraints
that have been added to the table and turn off the
constraint processing.
- remove(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove the constraint (and associated information) for the table descriptor.
- remove(Object) - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Remove metadata represented by the key from the map
- remove(Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Remove metadata represented by the key from the map
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Remove metadata represented by the key from the map
- remove() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCachesIterator
-
- remove(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
- remove(BlockCacheKey, Consumer<BucketCache.RAMQueueEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache
-
Defined an
Consumer
here, because once the removed entry release its reference count,
then it's ByteBuffers may be recycled and accessing it outside this method will be thrown an
exception.
- remove(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- remove(Object) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- remove() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- remove(Call) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
- remove(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- remove(ServerName) - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
- remove(Queue<T>) - Method in class org.apache.hadoop.hbase.master.procedure.FairQueue
-
- remove(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistriesImpl
-
- remove(String) - Method in class org.apache.hadoop.hbase.metrics.impl.MetricRegistryImpl
-
- remove(K) - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
Decrements the ref count of k, and removes from map if ref count == 0.
- remove(MetricRegistryInfo) - Method in class org.apache.hadoop.hbase.metrics.MetricRegistries
-
Decrements the ref count of the MetricRegistry, and removes if ref count == 0.
- remove(String) - Method in interface org.apache.hadoop.hbase.metrics.MetricRegistry
-
Removes the metric with the given name.
- remove(DelayedUtil.DelayedWithTimeout) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
-
- remove(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
-
Deprecated.
- remove(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
-
- remove(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- remove() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever.Iter
-
- remove(RegionInfo) - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Removes the mapping for the given key, returning the value if one exists in the store.
- remove(RegionInfo) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- remove(HRegionLocation) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Removes the given location from the list
- remove(int) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Removes location of the given replicaId from the list
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- remove() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapIterator
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- remove() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
-
- remove() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
-
- remove() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator
-
- remove(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
Remove head from the queue corresponding to given walGroupId.
- remove(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- remove() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- remove(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Returns Instance of table descriptor or null if none found.
- remove() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- remove(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- remove() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntryIterator
-
- remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- remove(int) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- remove() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeyIterator
-
- remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- remove() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueIterator
-
- remove(Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- remove(Object, Object) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- remove() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
- remove(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
-
Remove a node from the tree
- remove(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Removes the node matching the specified key from the tree
- remove(TNode, Object, AvlUtil.AvlKeyComparator<TNode>, AtomicBoolean) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Removes the node matching the specified key from the tree
- remove() - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- remove() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- remove(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Removes the table descriptor from the local cache and returns it.
- remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- remove(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- remove(R) - Method in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- remove(R) - Method in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- remove(int) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- remove(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- REMOVE_QUOTA_ON_TABLE_DELETE - Static variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- REMOVE_QUOTA_ON_TABLE_DELETE_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- removeAfterUnassigning - Variable in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- removeAllLastPushedSeqIds(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- removeAllLogs(long, String) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
Remove all logs with logId <= lastLogId
.
- removeAllQueues(ReplicationQueueStorage, String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- removeAllQueuesAndHFileRefs(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- removeBucket(BucketAllocator.Bucket) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- removeByServer(ServerName) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns a new RegionLocations with the locations removed (set to null) which have the
destination server as given.
- removeCatalogReplicationSource(RegionInfo) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Remove the hbase:meta Catalog replication source.
- removeChore(ProcedureInMemoryChore<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Remove a chore procedure from the executor
- removeChunk(int) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- removeChunks(Set<Integer>) - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Removes the ColumnFamilyDescriptor with name specified by the parameter column from the table
descriptor
- removeColumnFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeCompactedFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- removeCompactedfiles(Collection<HStoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Archives and removes the compacted files
- removeCompactedFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- removeCompactedFiles(Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Remove the compacted files
- removeCompactedFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
Remove compacted files.
- removeCompactedFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- removeCompletedOperation(TRemote, RemoteProcedureDispatcher.RemoteProcedure) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- removeComponents(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Remove a configuration setting represented by the key.
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Remove a config setting represented by the key from the map
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- removeConfiguration(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Removes a "raw" configuration property for this replication peer.
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Remove a coprocessor from those set on the table
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Remove a coprocessor from those set on the table
- removeData(long) - Method in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Update the statistics after removing the given data value n
- removeDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Called from rpc by operator cleaning up deadserver list.
- removeElementsWithNullLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Set the element to null if its getServerName method returns null.
- removeEntryFromStream(WALEntryStream, WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationSourceWALReader
-
- removeErrors(Action) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- removeExcessFiles(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- removeExistingNamespaceSnapshotSizes(Set<String>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- removeExistingSnapshotSizes(List<Delete>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- removeExistingTableSnapshotSizes(Multimap<TableName, String>) - Method in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- removeExpiredKeys() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- removeExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Remove an extra header.
- removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Removes the HColumnDescriptor with name specified by the parameter column from the table
descriptor
- removeFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
Remove a favored node assignment
- removeFile(Path) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- removeFirst() - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- removeFromFailedOpen(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- removeFromMovedRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- removeFromNamespaceUsage(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- removeFromNSTable(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- removeFromOfflineRegions(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- removeFromRamCache(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- removeFromRunQueue(FairQueue<T>, Queue<T>, Supplier<String>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- removeFromZKNamespaceManager(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
remove from ZooKeeper.
- removeFromZKNamespaceManager(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- removeHdfsRegions(ThreadPoolExecutor, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Remove specified regions from the file-system, using the archiver.
- removeHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeHFileRefs(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove hfile references from the queue.
- removeHFileRefs(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeHistogramMetrics(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- removeInactiveLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- removeInactiveLogsForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- removeKey(Integer) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- removeKeyFromZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- removeLastSequenceIds(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeLastSequenceIds(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeLastSequenceIds(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove all the max sequence id record for the given peer.
- removeLastSequenceIds(String, List<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove the max sequence id record for the given peer and regions.
- removeLastSequenceIds(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeLastSequenceIds(String, List<String>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeLease(String) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Remove named lease.
- removeListener() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
remove the listener for task changes.
- removeListener() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- removeLocationFromCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
-
- removeLocationFromCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
-
- removeLogFile(ProcedureWALFile, Path) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- removeMetaData(byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
-
- removeMetric(String) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Remove a metric and no longer announce it.
- removeMetric(String) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Remove a named gauge.
- removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- removeMetric(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- removeMetric(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Removes metric by name
- removeMin(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
- removeMirrorMetaLocation(int, int) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- removeMobFiles(Configuration, FileSystem, TableName, Path, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Archives the mob files.
- removeNamespace(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Remove given namespace from AuthManager's namespace cache.
- removeNamespaceAccessAcl(TableName, Set<String>, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Remove table access acl from namespace dir when delete table
- removeNamespaceDefaultAcl(String, Set<String>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Remove default acl from namespace archive dir when delete namespace
- removeNamespacePermissions(Configuration, String, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Remove specified namespace from the acl table.
- removeNamespaceQuota(MasterProcedureEnv, String) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
remove quota for the namespace
- removeNamespaceQuota(String) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- removeNamespaceSpaceLimit(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given
namespace.
- removeNode(TRemote) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
Remove a remote node
- removeNonDefaultRegions(Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Removes the non-default replicas from the passed regions collection n
- removeNonDefaultReplicas(MasterProcedureEnv, Stream<RegionInfo>, int) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- removeNonDefaultReplicas(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- removeNonDefaultReplicas(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- removeNonOnlineRegions(RegionSizeStore, Set<RegionInfo>) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- removeObjectMethod - Variable in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
-
- removeObjectName(String) - Method in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
-
- removeParentInMeta(Configuration, RegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
- removeParents - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- removeParentsAndFixSplits(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo.HDFSIntegrityFixer
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandler
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
1.
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- removePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Remove a replication peer.
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- removePeerFromHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removePeerFromHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove a peer from hfile reference queue.
- removePeerFromHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removePeerLock(String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- RemovePeerProcedure - Class in org.apache.hadoop.hbase.master.replication
-
The procedure for removing a replication peer.
- RemovePeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- RemovePeerProcedure(String) - Constructor for class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- removePeerQueue(String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- removePeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- removePeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- removePermissionRecord(Configuration, UserPermission, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- removeQueue(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- removeQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeQueue(ServerName, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove a replication queue for a given regionserver.
- removeQueue(ServerName, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeQuotesFromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a quoted byte array and converts it into an unquoted byte array For example: given a byte
array representing 'abc', it returns a byte array representing abc
- removeRecoveredSource(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Clear the metrics and related replication queue of the specified old source
- removeRegion(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- removeRegion(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- removeRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRegion(HRegion, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- removeRegion(HRegion, ServerName) - Method in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
-
Removes the given Region from the list of onlineRegions.
- removeRegionFromNamespaceUsage(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- removeRegionFromServer(ServerName, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- removeRegionFromTable(RegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- removeRegionLocation(RegionLocations, int) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
Create a new
RegionLocations
based on the given
oldLocs
, and remove the
location for the given
replicaId
.
- removeRegionLock(String) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- removeRegionReplicas(TableName, int, int) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- removeRegions(List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Called by delete table and similar to notify the ServerManager that a region was removed.
- removeRegionSizesForTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Removes each region size entry where the RegionInfo references the provided TableName.
- removeRegistry(MetricRegistry) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- removeReplicaColumnsIfNeeded(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
remove replica columns if necessary.
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove a peer and stop the replication.
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove a peer and stop the replication
- removeReplicationPeer(String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- removeReplicationPeer(String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- removeReplicationPeer(RpcController, ReplicationProtos.RemoveReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- removeReplicationPeer(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- removeReplicationPeer(RpcController, ReplicationProtos.RemoveReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- removeReplicationPeer(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Removes a peer and stops the replication
- removeReplicationPeerAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove a replication peer but does not block and wait for it.
- removeReplicationPeerAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- removeReplicationPeerAsync(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Remove some table-cfs from config of the specified peer.
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Remove some table-cfs from config of the specified peer
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- removeReplicationVisibilityTag(List<Tag>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- removeReplicatorIfQueueIsEmpty(ServerName) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeReplicatorIfQueueIsEmpty(ServerName) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove the record of region server if the queue is empty.
- removeReplicatorIfQueueIsEmpty(ServerName) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeResult(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Mark the specified completed procedure, as ready to remove.
- removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Removes RegionServer group associated with the given name.
- removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- removeRSGroup(RpcController, RSGroupAdminProtos.RemoveRSGroupRequest, RpcCallback<RSGroupAdminProtos.RemoveRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- removeRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Remove a region server group.
- removeRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
Removes the scanner associated with the specified ID from the internal id->scanner hash-map.
- removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
Removes the scanner associated with the specified ID from the internal HashMap.
- removeSentinelIfFinished(Map<TableName, SnapshotSentinel>, SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Return the handler if it is currently live and has the same snapshot target name.
- removeServer(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
Called by SCP at end of successful processing.
- removeServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
Remove given server from the group.
- removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- removeServerLock(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- removeServerQueue(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- removeServers(Set<Address>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Remove decommissioned servers from rsgroup.
- removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- removeServers(RpcController, RSGroupAdminProtos.RemoveServersRequest, RpcCallback<RSGroupAdminProtos.RemoveServersResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- removeServers(Set<Address>) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Remove decommissioned servers from rsgroup
- removeServers(Set<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV1
-
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV2
-
- removeSource(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Clear the metrics and related replication queue of the specified old source
- removeSourceName(String) - Method in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
-
Unfortunately Hadoop tries to be too-clever and permanently keeps track of all names registered
so far as a Source, thus preventing further re-registration of the source with the same name.
- removeStackIndex() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- removeStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Archives the specified store file from the specified family.
- removeStoreFiles(String, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Closes and archives the specified store files from the specified family.
- removeTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
-
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- removeTable(TableName) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
-
Remove given table from AuthManager's table cache.
- removeTableAcl(TableName, Set<String>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Remove table acls when modify table
- removeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig, String) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- removeTableDefaultAcl(TableName, Set<String>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Remove default acl from table archive dir when delete table
- removeTableFromNamespaceQuota(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
Remove table from namespace quota.
- removeTableLock(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- removeTablePermissions(Configuration, TableName, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Remove specified table from the _acl_ table.
- removeTablePermissions(TableName, byte[], Table, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- removeTablePermissions(Configuration, TableName, byte[], Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Remove specified table column from the acl table.
- removeTableQueue(TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- removeTableSpaceLimit(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
-
Creates a
QuotaSettings
object to remove the FileSystem space quota for the given
table.
- removeUnneededFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- removeUserGlobalHdfsAcl(Table, String, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- removeUserNamespaceHdfsAcl(Table, String, String, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- removeUserPermission(Configuration, UserPermission, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
Removes a previously granted permission from the stored access control lists.
- removeUserTableHdfsAcl(Table, String, TableName, UserPermission) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- removeValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- removeValue(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeValue(Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeValue(byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- removeWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- removeWAL(ServerName, String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Remove an WAL file from the given queue for a given regionserver.
- removeWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- removeWALRootPath(Path, Configuration) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Checks for the presence of the WAL log root path (using the provided conf object) in the given
path.
- rename(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Renames a directory.
- renameAndSetModifyTime(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
-
Rename rsgroup.
- renameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- renameRSGroup(RpcController, RSGroupAdminProtos.RenameRSGroupRequest, RpcCallback<RSGroupAdminProtos.RenameRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- renameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- renameRSGroup(String, String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
Rename RSGroup
- renameRSGroup(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- renderRegionDetails() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
-
- renew - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- renewer - Variable in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- renewLease() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- renewLease() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Allow the client to renew the scanner's lease on the server.
- renewLease() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- renewLease() - Method in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- renewLease(String) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
Renew a lease
- renewLease() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- reopen(MasterProcedureEnv, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- REOPEN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- reopenAfterFlush() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Returns if top of heap has changed (and KeyValueHeap has to try the next KV)
- reopenMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- reopenProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- reopenRegions(TableName, List<byte[]>, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Reopen regions provided in the argument
- reopenRegions(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- reopenRegionsForRollback(MasterProcedureEnv, List<RegionInfo>, int, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
-
- ReopenTableRegionsProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
Used for reopening the regions for a table.
- ReopenTableRegionsProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- ReopenTableRegionsProcedure(TableName) - Constructor for class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- ReopenTableRegionsProcedure(TableName, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- reorderBlocks(Configuration, LocatedBlocks, String) - Method in interface org.apache.hadoop.hbase.fs.HFileSystem.ReorderBlocks
-
- reorderBlocks(Configuration, LocatedBlocks, String) - Method in class org.apache.hadoop.hbase.fs.HFileSystem.ReorderWALBlocks
-
- ReorderWALBlocks() - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem.ReorderWALBlocks
-
- rep - Variable in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
- repeatedBytesKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- repeatedFailuresMap - Variable in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
- repeatedFileBytes - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- repeatedFileBytes - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- replace(Collection<StoreFileInfo>, Collection<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Add new store files and remove compacted store files after compaction.
- replace(Collection<StoreFileInfo>, Collection<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- replace(TableName, TableSchemaModel, UriInfo, Admin) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- replace(int, CopyOnWriteArrayMap.COWEntry<K, V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- replace(K, V, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- replace(K, V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- replace(Object, TNode) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace
-
- replaceAtIndex(int, ImmutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- REPLACED_VALUE_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- replacedValue - Variable in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- replaceRegion(int[], int, int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- replaceRegionLocation(RegionLocations, HRegionLocation) - Static method in class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
-
Create a new
RegionLocations
based on the given
oldLocs
, and replace the
location for the given
replicaId
with the given
loc
.
- replaceStoreFiles(Collection<HStoreFile>, Collection<HStoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- replaceStoreFiles(Collection<HStoreFile>, Collection<HStoreFile>, StoreEngine.IOExceptionRunnable, Runnable) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- replaceWriter(Path, Path, W) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Cleans up current writer closing it and then puts in place the passed in nextWriter
.
- replay(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replay the given changes when distributedLogReplay WAL edits from a failed RS.
- replay - Variable in class org.apache.hadoop.hbase.wal.WALEdit
-
- REPLAY_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- REPLAY_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- REPLAY_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- ReplayBatchOperation(HRegion, WALSplitUtil.MutationReplay[], long) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- replayCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Call to complete a compaction.
- replayFlush(List<String>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
Similar to commit, but called in secondary region replicas for replaying the flush cache from
primary region.
- replayFlush(List<String>, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
-
Similar to commit, but called in secondary region replicas for replaying the flush cache from
primary region.
- replayFlushInStores(WALProtos.FlushDescriptor, HRegion.PrepareFlushResult, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Replays the given flush descriptor by opening the flush files in stores and dropping the
memstore snapshots if requested.
- replayHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- replayHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- replayRecoveredEdits(Path, Map<byte[], Long>, CancelableProgressable, FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayRecoveredEditsForPaths(long, FileSystem, NavigableSet<Path>, CancelableProgressable, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayRecoveredEditsIfAny(Map<byte[], Long>, CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Read the edits put under this region by wal splitting process.
- replayWALBulkLoadEventMarker(WALProtos.BulkLoadDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALCompactionMarker(WALProtos.CompactionDescriptor, boolean, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Call to complete a compaction.
- replayWALFlushAbortMarker(WALProtos.FlushDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALFlushCannotFlushMarker(WALProtos.FlushDescriptor, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALFlushCommitMarker(WALProtos.FlushDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALFlushMarker(WALProtos.FlushDescriptor, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALFlushStartMarker(WALProtos.FlushDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Replay the flush marker from primary region by creating a corresponding snapshot of the store
memstores, only if the memstores do not have a higher seqId from an earlier wal edit (because
the events may be coming out of order).
- replayWALRegionEventMarker(WALProtos.RegionEventDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replayWALs(Configuration, FileSystem, Path, Path, RegionInfo, String, Path) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- REPLICA_ID - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- REPLICA_ID_DELIMITER - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
- REPLICA_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- REPLICA_ID_FORMAT - Static variable in interface org.apache.hadoop.hbase.client.RegionInfo
-
to keep appended int's sorted in string format.
- ReplicaCallIssuingRunnable(List<Action>, long) - Constructor for class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
- replicaCallTimeoutMicroSecondScan - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- replicaErrors - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaResultState
-
Errors for which it is not decided whether we will report them to user.
- replicaGetIndices - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Indices of replica gets in results.
- replicaId - Variable in class org.apache.hadoop.hbase.client.Action
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- replicaId(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- replicaId - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- replicaId - Variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- replicaId - Variable in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- ReplicaRegionServerCallable(int, HRegionLocation) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable
-
- replicaResultLock - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
The lock controls access to results.
- ReplicaResultState(int) - Constructor for class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaResultState
-
- replicaSwitched - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Do the shipping logic
- replicate() - Method in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- replicate(ReplicationEndpoint.ReplicateContext) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Replicate the given set of entries (in the context) to the other cluster.
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- replicate(ReplicationEndpoint.ReplicateContext) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- replicate - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- REPLICATE - Static variable in class org.apache.hadoop.hbase.util.CommonFSUtils.DfsBuilderUtility
-
- replicate(FSDataOutputStreamBuilder<?, ?>) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils.DfsBuilderUtility
-
Attempt to use builder API via reflection to call the replicate method on the given builder.
- replicateAllUserTables - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- replicateAllUserTables() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- replicateAllUserTables - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- ReplicateContext() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- replicatedConnection - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- replicatedScanner - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- replicatedTable - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- replicateEntries(List<WAL.Entry>, int, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- replicateEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Replicate this array of entries directly into the local cluster using the native client.
- replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
-
Carry on the list of log entries down to the sink
- replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Carry on the list of log entries down to the sink
- replicateLogEntries(List<AdminProtos.WALEntry>, CellScanner, String, String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- replicateWALEntry(RpcController, AdminProtos.ReplicateWALEntryRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Replicate WAL entries on the region server.
- REPLICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- Replication - Class in org.apache.hadoop.hbase.replication.regionserver
-
Gateway to Replication.
- Replication() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Empty constructor
- Replication.ReplicationStatisticsTask - Class in org.apache.hadoop.hbase.replication.regionserver
-
Statistics task.
- REPLICATION_BARRIER_CLEANER_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.cleaner.ReplicationBarrierCleaner
-
- REPLICATION_BARRIER_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The replication barrier family
- REPLICATION_BARRIER_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The replication barrier family as a string
- REPLICATION_BULKLOAD_COPY_HFILES_PERTHREAD_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- REPLICATION_BULKLOAD_COPY_HFILES_PERTHREAD_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
Number of hfiles to copy per thread during replication
- REPLICATION_BULKLOAD_COPY_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- REPLICATION_BULKLOAD_COPY_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
Maximum number of threads to allow in pool to copy hfiles during replication
- REPLICATION_BULKLOAD_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_BULKLOAD_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Replication cluster id of source cluster which uniquely identifies itself with peer cluster
- REPLICATION_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting replication codec class name
- REPLICATION_CONF_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directory where the source cluster file system client configuration are placed which is used by
sink cluster to copy HFiles from source cluster file system
- REPLICATION_DROP_ON_DELETED_COLUMN_FAMILY_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Drop edits for CFs that been deleted from the replication source and target
- REPLICATION_DROP_ON_DELETED_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_DROP_ON_DELETED_TABLE_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Drop edits for tables that been deleted from the replication source and target
- REPLICATION_PARENT_QUALIFIER - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
-
- REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- REPLICATION_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- REPLICATION_SCOPE_BYTES - Static variable in interface org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
-
- REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- REPLICATION_SCOPE_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for globally scoped data.
- REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for locally scoped data.
- REPLICATION_SERIALLY_WAITING_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- REPLICATION_SERIALLY_WAITING_KEY - Static variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- REPLICATION_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SINK_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SOURCE_MAXTHREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of threads used by the replication source for shipping edits to the sinks
- REPLICATION_SOURCE_MAXTHREADS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of threads used by the replication source for shipping edits to the sinks
- REPLICATION_SOURCE_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SOURCE_SHIPEDITS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for ReplicationSource shipeEdits timeout
- REPLICATION_SOURCE_SHIPEDITS_TIMEOUT_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SOURCE_TOTAL_BUFFER_DFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SOURCE_TOTAL_BUFFER_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max total size of buffered entries in all replication peers.
- REPLICATION_TRACKER_IMPL - Static variable in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- REPLICATION_WALENTRYFILTER_CONFIG_KEY - Static variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- REPLICATION_ZNODE - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
- REPLICATION_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
- ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
-
- ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
Constructor that creates a connection to the local ZooKeeper ensemble.
- ReplicationBarrierCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
- ReplicationBarrierCleaner(Configuration, Stoppable, Connection, ReplicationPeerManager) - Constructor for class org.apache.hadoop.hbase.master.cleaner.ReplicationBarrierCleaner
-
- replicationBarrierCleaner - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ReplicationBarrierResult(long[], RegionState.State, List<byte[]>) - Constructor for class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- replicationBatchCountCapacity - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- replicationBatchSizeCapacity - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- replicationBulkLoadDataEnabled - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- ReplicationChecker - Class in org.apache.hadoop.hbase.util.hbck
-
Check and fix undeleted replication queues for removed peerId.
- ReplicationChecker(Configuration, ZKWatcher, HbckErrorReporter) - Constructor for class org.apache.hadoop.hbase.util.hbck.ReplicationChecker
-
- replicationClusterId - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- replicationDelay - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- replicationDelay - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- replicationEndpoint - Variable in class org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
-
- replicationEndpoint - Variable in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
-
- replicationEndpoint - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationEndpoint - Interface in org.apache.hadoop.hbase.replication
-
ReplicationEndpoint is a plugin which implements replication to other HBase clusters, or other
systems.
- ReplicationEndpoint.Context - Class in org.apache.hadoop.hbase.replication
-
- ReplicationEndpoint.ReplicateContext - Class in org.apache.hadoop.hbase.replication
-
- replicationEndpointImpl - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- replicationEndpointImpl - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- ReplicationException - Exception in org.apache.hadoop.hbase.replication
-
An HBase Replication exception.
- ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- replicationExecutor - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- ReplicationFactory - Class in org.apache.hadoop.hbase.replication
-
A factory class for instantiating replication objects that deal with replication state.
- ReplicationFactory() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- replicationForBulkLoadDataEnabled - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- ReplicationFuture(HBaseAdmin, String, Long, Supplier<String>) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ReplicationFuture
-
- REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- ReplicationHFileCleaner - Class in org.apache.hadoop.hbase.replication.master
-
Implementation of a file cleaner that checks if a hfile is still scheduled for replication before
deleting it from hfile archive directory.
- ReplicationHFileCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- replicationLag - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- replicationLag - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- ReplicationListener - Interface in org.apache.hadoop.hbase.replication
-
The replication listener interface can be implemented if a class needs to subscribe to events
generated by the ReplicationTracker.
- replicationLoad - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- ReplicationLoad - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is used for exporting some of the info from replication metrics
- ReplicationLoad() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
default constructor
- replicationLoad - Variable in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- replicationLoadSink - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- ReplicationLoadSink - Class in org.apache.hadoop.hbase.replication
-
A HBase ReplicationLoad to present MetricsSink information
- ReplicationLoadSink(long, long, long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- ReplicationLoadSink.ReplicationLoadSinkBuilder - Class in org.apache.hadoop.hbase.replication
-
- ReplicationLoadSinkBuilder() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- ReplicationLoadSource - Class in org.apache.hadoop.hbase.replication
-
A HBase ReplicationLoad to present MetricsSource information
- ReplicationLoadSource(String, long, int, long, long, long, String, boolean, boolean, boolean, long, long) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- ReplicationLoadSource.ReplicationLoadSourceBuilder - Class in org.apache.hadoop.hbase.replication
-
- ReplicationLoadSourceBuilder() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- replicationLoadSourceEntries - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- ReplicationLogCleaner - Class in org.apache.hadoop.hbase.replication.master
-
Implementation of a log cleaner that checks if a log is still scheduled for replication before
deleting it when its TTL is over.
- ReplicationLogCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- replicationManager - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- replicationManager - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication.ReplicationStatisticsTask
-
- ReplicationObserver - Class in org.apache.hadoop.hbase.replication.regionserver
-
An Observer to add HFile References to replication queue.
- ReplicationObserver() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationObserver
-
- replicationPeer - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- replicationPeer - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- ReplicationPeer - Interface in org.apache.hadoop.hbase.replication
-
ReplicationPeer manages enabled / disabled state for the peer.
- ReplicationPeer.PeerState - Enum in org.apache.hadoop.hbase.replication
-
State of the peer, whether it is enabled or not
- ReplicationPeerConfig - Class in org.apache.hadoop.hbase.replication
-
A configuration for the replication peer cluster.
- ReplicationPeerConfig(ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- ReplicationPeerConfig() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl - Class in org.apache.hadoop.hbase.replication
-
- ReplicationPeerConfigBuilder - Interface in org.apache.hadoop.hbase.replication
-
- ReplicationPeerConfigBuilderImpl() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- ReplicationPeerConfigListener - Interface in org.apache.hadoop.hbase.replication
-
- ReplicationPeerConfigUpgrader - Class in org.apache.hadoop.hbase.replication.master
-
This class is used to upgrade TableCFs from HBase 1.0, 1.1, 1.2, 1.3 to HBase 1.4 or 2.x.
- ReplicationPeerConfigUpgrader(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationPeerConfigUpgrader
-
- ReplicationPeerConfigUtil - Class in org.apache.hadoop.hbase.client.replication
-
Helper for TableCFs Operations.
- ReplicationPeerConfigUtil() - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
-
- ReplicationPeerDescription - Class in org.apache.hadoop.hbase.replication
-
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription
- ReplicationPeerDescription(String, boolean, ReplicationPeerConfig) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerDescription
-
- ReplicationPeerImpl - Class in org.apache.hadoop.hbase.replication
-
- ReplicationPeerImpl(Configuration, String, boolean, ReplicationPeerConfig) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
Constructor that takes all the objects required to communicate with the specified peer, except
for the region server addresses.
- replicationPeerManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ReplicationPeerManager - Class in org.apache.hadoop.hbase.master.replication
-
Manages and performs all replication admin operations.
- ReplicationPeerManager(ReplicationPeerStorage, ReplicationQueueStorage, ConcurrentMap<String, ReplicationPeerDescription>, Configuration, String) - Constructor for class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- ReplicationPeerNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a replication peer can not be found
- ReplicationPeerNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.ReplicationPeerNotFoundException
-
- replicationPeers - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- replicationPeers - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- ReplicationPeers - Class in org.apache.hadoop.hbase.replication
-
This provides an class for maintaining a set of peer clusters.
- ReplicationPeers(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeers
-
- ReplicationPeerStorage - Interface in org.apache.hadoop.hbase.replication
-
Perform read/write to the replication peer storage.
- ReplicationProcedureBiConsumer(String, Supplier<String>) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ReplicationProcedureBiConsumer
-
- replicationQueueInfo - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationQueueInfo - Class in org.apache.hadoop.hbase.replication
-
This class is responsible for the parsing logic for a queue id representing a queue.
- ReplicationQueueInfo(String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
The passed queueId will be either the id of the peer or the handling story of that queue in the
form of id-servername-*
- replicationQueues - Variable in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- ReplicationQueueStorage - Interface in org.apache.hadoop.hbase.replication
-
Perform read/write to the replication queue storage.
- replicationRpcLimit - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- ReplicationRuntimeException - Exception in org.apache.hadoop.hbase.replication.regionserver
-
This exception is thrown when a replication source is terminated and source threads got
interrupted.
- ReplicationRuntimeException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.regionserver.ReplicationRuntimeException
-
- ReplicationRuntimeException(String) - Constructor for exception org.apache.hadoop.hbase.replication.regionserver.ReplicationRuntimeException
-
- replicationScope - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- replicationScope - Variable in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- ReplicationService - Interface in org.apache.hadoop.hbase.regionserver
-
Gateway to Cluster Replication.
- replicationSink - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- replicationSink - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication.ReplicationStatisticsTask
-
- ReplicationSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible for replicating the edits coming from another cluster.
- ReplicationSink(Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Create a sink for replication
- replicationSink - Variable in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- replicationSinkHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ReplicationSinkManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
Maintains a collection of peers to replicate to, and randomly selects a single peer to replicate
to per set of data to replicate.
- ReplicationSinkManager(ClusterConnection, String, HBaseReplicationEndpoint, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Instantiate for a single replication peer cluster.
- ReplicationSinkManager.SinkPeer - Class in org.apache.hadoop.hbase.replication.regionserver
-
Wraps a replication region server sink to provide the ability to identify it.
- replicationSinkMgr - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- ReplicationSinkService - Interface in org.apache.hadoop.hbase.regionserver
-
A sink for a replication stream has to expose this service.
- ReplicationSinkServiceImpl - Class in org.apache.hadoop.hbase.replication
-
- ReplicationSinkServiceImpl() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- ReplicationSinkServiceImpl.ReplicationStatisticsChore - Class in org.apache.hadoop.hbase.replication
-
- ReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
Class that handles the source of a replication stream.
- ReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationSource(Predicate<Path>, List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationSourceFactory - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationSourceFactory() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceFactory
-
- replicationSourceHandler - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ReplicationSourceInterface - Interface in org.apache.hadoop.hbase.replication.regionserver
-
Interface that defines a replication source
- ReplicationSourceLogQueue - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationSourceLogQueue(Configuration, MetricsSource, ReplicationSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- replicationSourceManager - Variable in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
-
- ReplicationSourceManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible to manage all the replication sources.
- ReplicationSourceManager(ReplicationQueueStorage, ReplicationPeers, Configuration, Server, FileSystem, Path, Path, UUID, WALFactory, MetricsReplicationGlobalSourceSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Creates a replication manager and sets the watch on all the other registered region servers
- ReplicationSourceManager.ReplicationQueueOperation - Interface in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
-
A source for a replication stream has to expose this service.
- ReplicationSourceShipper - Class in org.apache.hadoop.hbase.replication.regionserver
-
This thread reads entries from a queue and ships them.
- ReplicationSourceShipper(Configuration, String, ReplicationSourceLogQueue, ReplicationSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- ReplicationSourceShipper.WorkerState - Enum in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationSourceWALActionListener - Class in org.apache.hadoop.hbase.replication.regionserver
-
Used to receive new wals.
- ReplicationSourceWALActionListener(Configuration, ReplicationSourceManager) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- ReplicationSourceWALReader - Class in org.apache.hadoop.hbase.replication.regionserver
-
Reads and filters WAL entries, groups the filtered entries into batches, and puts the batches
onto a queue
- ReplicationSourceWALReader(FileSystem, Configuration, ReplicationSourceLogQueue, long, WALEntryFilter, ReplicationSource, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
Creates a reader worker for a given WAL queue.
- ReplicationStatisticsChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl.ReplicationStatisticsChore
-
- ReplicationStatisticsTask(ReplicationSink, ReplicationSourceManager) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication.ReplicationStatisticsTask
-
- ReplicationStatus - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationStatus(ReplicationStatus.ReplicationStatusBuilder) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
-
- ReplicationStatus.ReplicationStatusBuilder - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationStatusBuilder() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
-
- ReplicationStorageFactory - Class in org.apache.hadoop.hbase.replication
-
Used to create replication storage(peer, queue) classes.
- ReplicationStorageFactory() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationStorageFactory
-
- ReplicationSyncUp - Class in org.apache.hadoop.hbase.replication.regionserver
-
In a scenario of Replication based Disaster/Recovery, when hbase Master-Cluster crashes, this
tool is used to sync-up the delta from Master to Slave using the info from ZooKeeper.
- ReplicationSyncUp() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- ReplicationSyncUp.DummyServer - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationThrottler - Class in org.apache.hadoop.hbase.replication.regionserver
-
Per-peer per-node throttling controller for replication: enabled if bandwidth > 0, a cycle =
100ms, by throttling we guarantee data pushed to peer within each cycle won't exceed 'bandwidth'
bytes
- ReplicationThrottler(double) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
ReplicationThrottler constructor If bandwidth less than 1, throttling is disabled
- REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- ReplicationUtils - Class in org.apache.hadoop.hbase.replication
-
Helper class for replication.
- ReplicationUtils() - Constructor for class org.apache.hadoop.hbase.replication.ReplicationUtils
-
- replicationZNode - Variable in class org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
-
The name of the base znode that contains all replication state.
- replicationZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- report(SortedMap<String, Gauge>, SortedMap<String, Counter>, SortedMap<String, Histogram>, SortedMap<String, Meter>, SortedMap<String, Timer>) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter
-
- report - Variable in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
Report is not done until after the close has been called.
- report(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
Report error information, but do not increment the error count.
- report(HbckErrorReporter) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Print a human readable summary of hfile quarantining operations.
- report(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- REPORT_JOB_ID - Static variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
- REPORT_SIZE - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- REPORT_START_DATETIME - Static variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
- reportActivity() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- reportArchivedFilesForQuota(List<? extends StoreFile>, List<Long>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- reportBadSink(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Report a SinkPeer
as being bad (i.e.
- reportCompactionRequestEnd(boolean, int, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- reportCompactionRequestFailure() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- reportCompactionRequestStart(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- reportEmptyMetaCells() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
TODO -- need to add tests for this.
- reporter - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- reporter - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- reporter - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
- reportError(HbckErrorReporter.ERROR_CODE, String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- reportError(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- reportError(String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportError(HbckErrorReporter.ERROR_CODE, String, HbckTableInfo, HbckRegionInfo, HbckRegionInfo) - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- reportFileArchival(RpcController, RegionServerStatusProtos.FileArchiveNotificationRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportFileArchivalForQuotas(TableName, Collection<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- reportFileArchivalForQuotas(TableName, Collection<Map.Entry<String, Long>>) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Reports a collection of files, and their sizes, that belonged to the given table
were
just moved to the archive directory.
- reportForDuty() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ReportMakingVisitor - Class in org.apache.hadoop.hbase.master.janitor
-
Visitor we use in here in CatalogJanitor to go against hbase:meta table.
- ReportMakingVisitor(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- reportMobCompactionEnd(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- reportMobCompactionStart(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- reportOnlineRegions(ServerName, Set<byte[]>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
The master will call this method when the RS send the regionServerReport().
- reportOperationFromWal(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Reports the operation from WAL during replay.
- reportPeriod - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- reportProcedureDone(RpcController, RegionServerStatusProtos.ReportProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportProcedureDone(RegionServerStatusProtos.ReportProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- reportRegionSizesForQuotas(RegionSizeStore) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Reports the given map of Regions and their size on the filesystem to the active Master.
- reportRegionSizesForQuotas(RegionSizeStore) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Reports the provided Region sizes hosted by this RegionServer to the active Master.
- reportRegionSpaceUse(RpcController, RegionServerStatusProtos.RegionSpaceUseReportRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportRegionStateTransition(RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder, ServerName, List<RegionServerStatusProtos.RegionStateTransition>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- reportRegionStateTransition(RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- reportRegionStateTransition(RpcController, RegionServerStatusProtos.ReportRegionStateTransitionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- reportRegionStateTransition(RegionServerServices.RegionStateTransitionContext) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Notify master that a handler requests to change a region state
- reportRSFatalError(RpcController, RegionServerStatusProtos.ReportRSFatalErrorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- reportServerError(ServerName) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
Reports that there was an error on the server to do whatever bean-counting necessary.
- reportSinkSuccess(ReplicationSinkManager.SinkPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Report that a SinkPeer
successfully replicated a chunk of data.
- reportTablesInFlux() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
TODO -- need to add tests for this.
- reportTimestamp - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- reportTimestamp - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- reportTransition(RegionStateNode, ServerStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- reportTransition(MasterProcedureEnv, RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- reportTransition(MasterProcedureEnv, RegionStateNode, ServerName, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- reportTransition(MasterProcedureEnv, RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- reportTransition(MasterProcedureEnv, RegionStateNode, ServerName, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long, long) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- reportTransition(MasterProcedureEnv, RegionStateNode, RegionServerStatusProtos.RegionStateTransition.TransitionCode, long) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- REQ_BASE - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- reqCapacityUnitLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- reqCleanup - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- reqHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
-
- reqSizeLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- reqsLimiter - Variable in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- request - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- request(Path, Runnable) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- request - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- request - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- request - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- request - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- request - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
-
- request - Variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet.HttpKerberosServerAction
-
- request - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- REQUEST_CONTROLLER_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RequestControllerFactory
-
- REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- REQUEST_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- REQUEST_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- requestCachingCounts - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
Caching access counts for each period in window
- requestCompaction(HRegion, String, int, CompactionLifeCycleTracker, User) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester
-
Request compaction on all the stores of the given region.
- requestCompaction(HRegion, HStore, String, int, CompactionLifeCycleTracker, User) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester
-
Request compaction on the given store.
- requestCompaction(HRegion, String, int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestCompaction(HRegion, HStore, String, int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestCompaction(String, int, boolean, CompactionLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- requestCompaction(byte[], String, int, boolean, CompactionLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- requestCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- requestCompaction(int, CompactionLifeCycleTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- requestCompaction(String, int, boolean, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request compaction on this region.
- requestCompaction(byte[], String, int, boolean, CompactionLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request compaction for the given family
- requestCompactionInternal(HRegion, String, int, boolean, CompactionLifeCycleTracker, CompactSplit.CompactionCompleteTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestCompactionInternal(HRegion, HStore, String, int, boolean, CompactionLifeCycleTracker, CompactSplit.CompactionCompleteTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestController - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
The traffic control for requests.
- RequestController - Interface in org.apache.hadoop.hbase.client
-
An interface for client request scheduling algorithm.
- RequestController.Checker - Interface in org.apache.hadoop.hbase.client
-
Picks up the valid data.
- RequestController.ReturnCode - Enum in org.apache.hadoop.hbase.client
-
- RequestControllerFactory - Class in org.apache.hadoop.hbase.client
-
- RequestControllerFactory() - Constructor for class org.apache.hadoop.hbase.client.RequestControllerFactory
-
- requestCorePoolDecrease() - Method in class org.apache.hadoop.hbase.ChoreService
-
Represents a request to decrease the number of core pool threads.
- requestCorePoolIncrease() - Method in class org.apache.hadoop.hbase.ChoreService
-
Represents a request to increase the number of core pool threads.
- requestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- requestCount - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- requestCount - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- RequestCountPerSecond - Class in org.apache.hadoop.hbase.hbtop.mode
-
Utility class for calculating request counts per second.
- RequestCountPerSecond() - Constructor for class org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
-
- requestCountPerSecond - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- requestCountPerSecond - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- requestCountPerSecondMap - Variable in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
-
- requestCountPerSecondMap - Variable in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
- requestCounts - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
Access counts for each period in window
- requestDelayedFlush(HRegion, long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed after a delay
- requestDelayedFlush(HRegion, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- requestedCharset(MediaType) - Static method in class org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter
-
- requestedQopContainsPrivacy() - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- requestedSize - Variable in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- requestedSize() - Method in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- requestFlush() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- requestFlush(HRegion, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requestFlush(HRegion, List<byte[]>, FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requestFlush() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- requestFlush(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- requestFlush(HRegion, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- requestFlush(HRegion, List<byte[]>, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- requestFlush(FlushLifeCycleTracker) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Request flush on this region.
- requestFlush0(FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- requestFlushIfNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- RequestHandler(AsyncConnection, ChannelGroup) - Constructor for class org.apache.hadoop.hbase.client.example.HttpProxyExample.RequestHandler
-
- RequestHeapSizeChecker(long) - Constructor for class org.apache.hadoop.hbase.client.SimpleRequestController.RequestHeapSizeChecker
-
- requestLock() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
Sends rpc to the master to request lock.
- requestLock(RpcController, LockServiceProtos.LockRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- requestLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- requestLogRoll(WALActionsListener.RollRequestReason) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- requestLogRoll(WAL) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
request a log roll, but don't actually do it.
- requestNamespaceLock(String, LockType, String, NonceKey) - Method in class org.apache.hadoop.hbase.master.locking.LockManager.RemoteLocks
-
- RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- requestRegionsLock(RegionInfo[], String, NonceKey) - Method in class org.apache.hadoop.hbase.master.locking.LockManager.RemoteLocks
-
- requestRegionSplit() - Method in class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- requestRoll() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
-
- requestRollAll() - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- requestRollAll() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- RequestRowsChecker(long) - Constructor for class org.apache.hadoop.hbase.client.SimpleRequestController.RequestRowsChecker
-
- requests - Variable in class org.apache.hadoop.hbase.io.hfile.BloomFilterMetrics
-
- requests - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- requests - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- requestsCountCache - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- requestSeek(Cell, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- requestSeek(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Pretend we have done a seek but don't do it yet, if possible.
- requestSize - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- requestSizeBytes - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- requestsPerSecond - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- requestSplit(Region) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestSplit(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestSplit(Region, byte[], User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestSystemCompaction(HRegion, HStore, String, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester
-
Request system compaction on the given store.
- requestSystemCompaction(HRegion, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestSystemCompaction(HRegion, HStore, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestSystemCompaction(HRegion, HStore, String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- requestTableLock(TableName, LockType, String, NonceKey) - Method in class org.apache.hadoop.hbase.master.locking.LockManager.RemoteLocks
-
- requestTooBig - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- RequestTooBigException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the size of the rpc request received by the server is too large.
- RequestTooBigException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
-
- RequestTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
-
- requestTooBigException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- requestTooBigException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- requestTooBigMessage - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- requestTooBigSent - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- requestWriteBlock(Channel, StorageType, DataTransferProtos.OpWriteBlockProto.Builder) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- requeue(long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- requeueCount - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry
-
- requireAccess(User, String, TableName, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Authorizes that the current user has any of the given permissions to access the table.
- requireAccess(ObserverContext<?>, String, TableName, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireAccess(User, String, TableName, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.MetaQueue
-
Deprecated.
- requireExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.PeerQueue
-
- requireExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- requireExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.ServerQueue
-
- requireExclusiveLock(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.procedure.TableQueue
-
- requireGlobalPermission(User, String, Permission.Action, TableName, Map<byte[], ? extends Collection<byte[]>>, String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Checks that the user has the given global permission.
- requireGlobalPermission(User, String, Permission.Action, String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Checks that the user has the given global permission.
- requireGlobalPermission(ObserverContext<?>, String, Permission.Action, TableName, Map<byte[], ? extends Collection<byte[]>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireGlobalPermission(ObserverContext<?>, String, Permission.Action, String) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireGlobalPermission(User, String, Permission.Action, TableName, Map<byte[], ? extends Collection<byte[]>>, String) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireGlobalPermission(User, String, Permission.Action, String) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireNamespacePermission(User, String, String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Checks that the user has the given global or namespace permission.
- requireNamespacePermission(User, String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Checks that the user has the given global or namespace permission.
- requireNamespacePermission(ObserverContext<?>, String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireNamespacePermission(ObserverContext<?>, String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireNamespacePermission(User, String, String, String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireNamespacePermission(User, String, String, TableName, Map<byte[], ? extends Collection<byte[]>>, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requirePeerExclusiveLock(PeerProcedureInterface) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- requirePeerExclusiveLock(PeerProcedureInterface) - Static method in class org.apache.hadoop.hbase.master.procedure.PeerQueue
-
- requirePermission(String, Permission.Action) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- requirePermission(User, String, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Authorizes that the current user has global privileges for the given action.
- requirePermission(User, String, TableName, byte[], byte[], String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Authorizes that the current user has any of the given permissions for the given table, column
family and column qualifier.
- requirePermission(ObserverContext<?>, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requirePermission(ObserverContext<?>, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requirePermission(User, String, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requirePermission(User, String, TableName, byte[], byte[], String, Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireScannerOwner(InternalScanner) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Verify, when servicing an RPC, that the caller is the scanner owner.
- requireScannerOwner(InternalScanner) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Verify, when servicing an RPC, that the caller is the scanner owner.
- requiresReplication(TableName, List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
returns true if the specified entry must be replicated.
- requireTableExclusiveLock(TableProcedureInterface) - Static method in class org.apache.hadoop.hbase.master.procedure.TableQueue
-
- requireTablePermission(User, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
Authorizes that the current user has any of the given permissions for the given table, column
family and column qualifier.
- requireTablePermission(ObserverContext<?>, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- requireTablePermission(User, String, TableName, byte[], byte[], Permission.Action...) - Method in class org.apache.hadoop.hbase.security.access.NoopAccessChecker
-
- requireWritingToTmpDirFirst() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Whether the implementation of the used storefile tracker requires you to write to temp
directory first, i.e, does not allow broken store files under the actual data directory.
- requireWritingToTmpDirFirst() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.DefaultStoreFileTracker
-
- requireWritingToTmpDirFirst() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.FileBasedStoreFileTracker
-
- requireWritingToTmpDirFirst() - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- requireWritingToTmpDirFirst() - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Whether the implementation of this tracker requires you to write to temp directory first, i.e,
does not allow broken store files under the actual data directory.
- rerun - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- rescan(long) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
signal the workers that a task was resubmitted by creating the RESCAN node.
- rescheduleChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
This function is identical to the
KeyValueHeap.seek(Cell)
function except that
scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
- reseek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Do a reseek to the required row.
- reseek(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- reseek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- reseekAtOrAfter(HFileScanner, Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- reseekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- reseekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Reseek to or just before the passed cell
.
- RESERVED_KEYWORDS - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- RESERVED_KEYWORDS - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- RESERVED_NAMESPACES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- RESERVED_NAMESPACES_BYTES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- RESERVED_PREFIX - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- RESERVED_PREFIX_BYTES - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- RESERVED_VIS_TAG_TYPES - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- reserveForCompaction(ServerName) - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
-
- reservoirEnabled - Variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
-
- ReservoirSample<T> - Class in org.apache.hadoop.hbase.util
-
The simple version of reservoir sampling implementation.
- ReservoirSample(int) - Constructor for class org.apache.hadoop.hbase.util.ReservoirSample
-
- reset() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- reset() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- reset(ServerName, MultiAction) - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- reset() - Method in interface org.apache.hadoop.hbase.client.RequestController.Checker
-
Reset the state of the scheduler when completing the iteration of rows.
- reset() - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestHeapSizeChecker
-
- reset() - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestRowsChecker
-
- reset() - Method in interface org.apache.hadoop.hbase.client.SimpleRequestController.RowChecker
-
Reset the inner state.
- reset() - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.SubmittedSizeChecker
-
- reset() - Method in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Reset the state of the filter between rows.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are purely stateless and do nothing in their reset() methods can inherit this
null/empty implementation.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- reset() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- reset() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- reset() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Resets the pos
field of this byte array output stream to zero.
- reset() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- reset() - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- reset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- reset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- reset() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- reset() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- reset() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- reset() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Similar to
ByteBuffer
.reset(), ensures that this ByteBuff is reset back to last marked
position.
- reset() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Similar to
ByteBuffer
.reset(), ensures that this MBB is reset back to last marked
position.
- reset() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- reset() - Method in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- reset() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
-
Reset the Iterator by seeking to the beginning of the list.
- reset() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- reset() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- reset() - Static method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
-
Reset the offset to UNINITIALIZED before before reusing an old chunk
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
-
Resets the Matcher
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
-
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
-
Called between rows.
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- reset(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
Call this method to clear old usage and get it ready for new deploy.
- reset() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
Should be called if the stream is to be reused (i.e.
- reset() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- reset() - Method in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- reset() - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- reset() - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
- reset() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- reset() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- reset() - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Reset the sequence of accumulated fields.
- reset() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
- reset() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- RESET_THRESHOLD - Static variable in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- RESET_TTL - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- ResetableGZIPOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream.ResetableGZIPOutputStream
-
- resetAcls(ZKWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
-
- resetAcls(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
-
- resetActive() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- resetBuf(int) - Method in class org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
-
- resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Enable a basic on-heap cache for these jobs.
- resetCallTimeout() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- resetCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- resetChangesAfterLastFlush() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- resetContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteArrayBackedNode
-
- resetContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteBufferBackedNode
-
- resetContents() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.Node
-
- resetController(HBaseRpcController, long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- resetCounters() - Static method in class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- resetDelay - Variable in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- resetErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- resetErrors() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- resetExclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
Resets the exclusive flag.
- resetExpirationTime() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager.Lease
-
Resets the expiration time of the lease.
- resetFailuresCountDetails() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionStdOutSink
-
- resetFilters() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
Reset both the filter and the old filter.
- resetHighest() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
Reset the accounting of highest sequenceid by regionname.
- resetInternal() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- resetInternal() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker
-
- resetKVHeap(List<? extends KeyValueScanner>, CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- resetMasterServiceState(ConnectionImplementation.MasterServiceState) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- resetMembers(Procedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify Members to reset the distributed state for procedure
- resetMembers(Procedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
Delete znodes that are no longer in use.
- resetModified() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
- resetModified() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Clears the list of updated procedure ids.
- resetMvccReadPoint() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- resetMvccReadPoint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the mvcc read point to -1 which means do not use it.
- resetPersistence() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- resetProgress(ScannerContext, int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- resetQueryMatcher(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- resetReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- resetRSGroupAndTableMaps(Map<String, RSGroupInfo>, Map<TableName, String>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
Make changes visible.
- resetSplitParent(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Reset the split parent region info in meta table
- resetStartTick() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Reset the cycle start tick to NOW
- resetState() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream.ResetableGZIPOutputStream
-
- resetState() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
-
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- resetStats() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- resetTempDir() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Cleans up any snapshots in the snapshot/.tmp directory that were left from failed snapshot
attempts.
- resetTimeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- resetTo(ProcedureStoreTracker) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Resets internal state to same as given tracker
.
- resetTo(ProcedureStoreTracker, boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Resets internal state to same as given tracker
, and change the deleted flag according
to the modified flag if resetDelete
is true.
- resetToProto(ProcedureProtos.ProcedureStoreTracker) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- resetTS() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- resetTSAndType() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- resetTTL(ScanOptions) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- resetTtl - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- Resigned(ServerName) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
-
Deprecated.
- ResignedWALSplitException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException
-
- ResizableBlockCache - Interface in org.apache.hadoop.hbase.io.hfile
-
BlockCache which is resizable.
- resizeQueues(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Update current soft limit for executor's call queues
- resolve(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file, and the read point does not count.
- resolve(Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file with readEmptyValueOnMobCellMiss
- resolve(Cell, boolean, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Reads the cell from the mob file.
- resolveAndArchive(FileSystem, Path, Collection<HFileArchiver.File>, long) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Resolve any conflict with an existing archive file via timestamp-append renaming of the
existing file and then archive the passed in files.
- resolveAndArchiveFile(Path, HFileArchiver.File, String) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Attempt to archive the passed in file to the archive directory.
- resolveDeprecatedClassName(String) - Static method in class org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
-
Resolve deprecated class name to keep backward compatibiliy
- resolveName(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- resolveRequestParameter(HttpServletRequest, String) - Static method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- ResolverUrlClassLoader(URL[], ClassLoader) - Constructor for class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator.ResolverUrlClassLoader
-
- resolveScanLimit(HttpServletRequest) - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- resolveScanRegionState(HttpServletRequest) - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- resolveScanStart(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- resolveScanTable(HttpServletRequest) - Static method in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- RESOURCE_LOAD_PARENT_FIRST_PATTERNS - Static variable in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
If the resource being loaded matches any of these patterns, we will first attempt to load the
resource with the parent ClassLoader.
- RESOURCE_SCHEME - Static variable in class org.apache.hadoop.hbase.io.compress.DictionaryCache
-
- ResourceBase - Class in org.apache.hadoop.hbase.rest
-
- ResourceBase() - Constructor for class org.apache.hadoop.hbase.rest.ResourceBase
-
- ResourceConfigFactory - Class in org.apache.hadoop.hbase.master.http.api_v1
-
Encapsulates construction and configuration of the ResourceConfig
that implements the
cluster-metrics
endpoints.
- ResourceConfigFactory() - Constructor for class org.apache.hadoop.hbase.master.http.api_v1.ResourceConfigFactory
-
- resourceName - Variable in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- resources - Variable in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- resources - Variable in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- resourceType - Variable in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- resp - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner.OpenScannerResponse
-
- resp - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- resp - Variable in class org.apache.hadoop.hbase.rest.client.Client
-
- resp - Variable in class org.apache.hadoop.hbase.rest.client.Response
-
- RESP_BASE - Static variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- respHist - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
-
- responder - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- responder - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerCall
-
Deprecated.
- responder - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- response - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- response - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
Chain of buffers to send as response.
- Response - Class in org.apache.hadoop.hbase.rest.client
-
The HTTP result code, response headers, and body of an HTTP response.
- Response(int) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], HttpResponse, InputStream) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor.
- response - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- response - Variable in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- RESPONSE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- RESPONSE_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- responseBlockSize - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- responseCellSize - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- responseConnectionHeader(RPCProtos.ConnectionHeaderResponse.Builder) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
Send the response for connection header
- responseDefaultType - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- ResponseEntityMapper - Class in org.apache.hadoop.hbase.http.jersey
-
Generate a uniform response wrapper around the Entity returned from the resource.
- ResponseEntityMapper() - Constructor for class org.apache.hadoop.hbase.http.jersey.ResponseEntityMapper
-
- responseQueue - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- responseSize - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- responseSize - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- responseSize - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- responseSize - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- responseSizeBytes - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- ResponseType() - Constructor for enum org.apache.hadoop.hbase.client.AbstractResponse.ResponseType
-
- responseWriteLock - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- REST_AUTHENTICATION_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_AUTHENTICATION_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_CLIENT_CONN_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
Configuration parameter to set rest client connection timeout
- REST_CLIENT_SOCKET_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
Configuration parameter to set rest client socket timeout
- REST_CONNECTOR_ACCEPT_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_CSRF_BROWSER_USERAGENTS_REGEX_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_CUSTOM_HEADER_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_CUSTOM_HEADER_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_METHODS_TO_IGNORE_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_CSRF_METHODS_TO_IGNORE_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_DNS_INTERFACE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_HTTP_ALLOW_OPTIONS_METHOD - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_HTTP_ALLOW_OPTIONS_METHOD_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- REST_KERBEROS_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_KEYTAB_FILE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_PREFIX - Static variable in class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
- REST_PREFIX_LEN - Static variable in class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
- REST_SSL_ENABLED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_EXCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_EXCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_INCLUDE_CIPHER_SUITES - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_INCLUDE_PROTOCOLS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_KEYPASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_TRUSTSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_TRUSTSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_TRUSTSTORE_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_THREAD_POOL_TASK_QUEUE_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_THREAD_POOL_THREAD_IDLE_TIMEOUT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_THREAD_POOL_THREADS_MAX - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_THREAD_POOL_THREADS_MIN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Restart from survivable exceptions by creating a new scanner.
- restart() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
-
Restarts the stopped service.
- restartedKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- restartWALReading - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- restartWALReading - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- restartWriterThreadsIfNeeded() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- restCSRFEnabled - Variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- RestCsrfPreventionFilter - Class in org.apache.hadoop.hbase.rest.filter
-
This filter provides protection against cross site request forgery (CSRF) attacks for REST APIs.
- RestCsrfPreventionFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- RestCsrfPreventionFilter.HttpInteraction - Interface in org.apache.hadoop.hbase.rest.filter
-
Defines the minimal API requirements for the filter to execute its filtering logic.
- RestCsrfPreventionFilter.ServletFilterHttpInteraction - Class in org.apache.hadoop.hbase.rest.filter
-
- RESTORE_DIR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- RESTORE_DIRS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- restoreAcl - Variable in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- restoreAcl - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- restoreDir - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- restoreDir - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- restoreEdit(HStore, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Used by tests
- restoreHdfsIntegrity() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
This method determines if there are table integrity errors in HDFS.
- restoreHdfsMobRegions(ThreadPoolExecutor, Map<String, SnapshotProtos.SnapshotRegionManifest>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore specified mob regions by restoring content to the snapshot state.
- restoreHdfsRegions() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore the on-disk table to a specified snapshot state.
- restoreHdfsRegions(ThreadPoolExecutor) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- restoreHdfsRegions(ThreadPoolExecutor, Map<String, SnapshotProtos.SnapshotRegionManifest>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore specified regions by restoring content to the snapshot state.
- restoreLastMutation() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- restoreLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- restoreLock(Procedure<TEnvironment>, Set<Long>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- restoreLocks(Deque<Procedure<TEnvironment>>, Set<Long>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- restoreLocks() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- RestoreMetaChanges(TableDescriptor, Map<String, Pair<String, String>>) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- restoreMobRegion(RegionInfo, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore mob region by removing files not in the snapshot and adding the missing ones from the
snapshot.
- restoreOrCloneSnapshot(SnapshotProtos.SnapshotDescription, NonceKey, boolean, String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Restore or Clone the specified snapshot n * @param nonceKey unique identifier to prevent
duplicated RPC n
- restoreReferenceFile(Path, RegionInfo, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
Reference
as copy of the source one.
- restoreRegion(RegionInfo, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore region by removing files not in the snapshot and adding the missing ones from the
snapshot.
- restoreRegion(RegionInfo, SnapshotProtos.SnapshotRegionManifest, Path) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore region by removing files not in the snapshot and adding the missing ones from the
snapshot.
- restoreSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- restoreSnapshot(String, TableName, boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- restoreSnapshot(Configuration, String, Path, Path, FileSystem) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- restoreSnapshot(SnapshotProtos.SnapshotDescription, long, long, boolean, String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- restoreSnapshot(RpcController, MasterProtos.RestoreSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Execute Restore/Clone snapshot operation.
- restoreSnapshot(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Execute the on-disk Restore
- restoreSnapshot(SnapshotProtos.SnapshotDescription, TableName, SnapshotProtos.SnapshotDescription, TableDescriptor, NonceKey, boolean) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Restore the specified snapshot.
- restoreSnapshot(SnapshotProtos.SnapshotDescription, TableDescriptor, NonceKey, boolean) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Restore the specified snapshot.
- restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- restoreSnapshot(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- restoreSnapshotAcl(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- restoreSnapshotAcl(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- restoreSnapshotAcl(SnapshotProtos.SnapshotDescription, TableName, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- restoreSnapshotAsync(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- restoreSnapshotAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- restoreSnapshotAsync(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
- RestoreSnapshotException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- restoreSnapshotForPeerCluster(Configuration, String) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- RestoreSnapshotFuture(HBaseAdmin, SnapshotProtos.SnapshotDescription, TableName, MasterProtos.RestoreSnapshotResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.RestoreSnapshotFuture
-
- RestoreSnapshotFuture(HBaseAdmin, TableName, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.RestoreSnapshotFuture
-
- RestoreSnapshotHelper - Class in org.apache.hadoop.hbase.snapshot
-
Helper to Restore/Clone a Snapshot
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, TableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RestoreSnapshotHelper(Configuration, FileSystem, SnapshotManifest, TableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask, boolean) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RestoreSnapshotHelper.RestoreMetaChanges - Class in org.apache.hadoop.hbase.snapshot
-
Describe the set of operations needed to update hbase:meta after restore.
- RestoreSnapshotProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- RestoreSnapshotProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Constructor (for failover)
- RestoreSnapshotProcedure(MasterProcedureEnv, TableDescriptor, SnapshotProtos.SnapshotDescription) - Constructor for class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- RestoreSnapshotProcedure(MasterProcedureEnv, TableDescriptor, SnapshotProtos.SnapshotDescription, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
Constructor
- restoreSnapshots(Configuration, Map<String, Path>, FileSystem) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
Restore each (snapshot name, restore directory) pair in snapshotToDir
- restoreStoreFile(Path, RegionInfo, SnapshotProtos.SnapshotRegionManifest.StoreFile, boolean) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
HFileLink
to reference the store file.
- restoreSucceedState(AssignmentManager, RegionStateNode, long) - Method in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- restoreSucceedState(AssignmentManager, RegionStateNode, long) - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- restoreSucceedState(AssignmentManager, RegionStateNode, long) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- restoreTableToProcIdMap - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- RESTRICTION_TYPE_DELIMITED_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
- RESTRICTION_TYPE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
- RESTRICTION_TYPE_KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
- RESTRICTION_TYPE_NONE - Static variable in class org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
-
- RESTServer - Class in org.apache.hadoop.hbase.rest
-
Main class for launching REST gateway as a servlet hosted by Jetty.
- RESTServer(Configuration) - Constructor for class org.apache.hadoop.hbase.rest.RESTServer
-
- RESTServlet - Class in org.apache.hadoop.hbase.rest
-
Singleton class encapsulating global REST servlet state and functions.
- RESTServlet(Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.rest.RESTServlet
-
Constructor with existing configuration
- RESTServletContainer - Class in org.apache.hadoop.hbase.rest
-
REST servlet container.
- RESTServletContainer(ResourceConfig) - Constructor for class org.apache.hadoop.hbase.rest.RESTServletContainer
-
- restVersion - Variable in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- resubmit(ServerName, List<Action>, int, int, Throwable) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Log as much info as possible, and, if there is something to replay, submit it again after a
back off sleep.
- resubmit(String, int) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- ResubmitDirective() - Constructor for enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
- resubmitFailedPut(HTableMultiplexer.PutStatus, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- resubmitOrFail(String, SplitLogManager.ResubmitDirective) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Resubmit the task in case if found unassigned or failed
- resubmitTask(String, SplitLogManager.Task, SplitLogManager.ResubmitDirective) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- resubmitThreshold - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- resubmitThresholdReached - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- result - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.RegionLocationsFutureResult
-
- result - Variable in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
- result - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- result - Variable in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- Result - Class in org.apache.hadoop.hbase.client
-
Single row result of a
Get
or
Scan
query.
- Result() - Constructor for class org.apache.hadoop.hbase.client.Result
-
Creates an empty Result w/ no KeyValue payload; returns null if you call
Result.rawCells()
.
- Result(boolean) - Constructor for class org.apache.hadoop.hbase.client.Result
-
Allows to construct special purpose immutable Result objects, such as EMPTY_RESULT.
- Result(Cursor) - Constructor for class org.apache.hadoop.hbase.client.Result
-
- Result(Cell[], Boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.client.Result
-
Private ctor.
- result - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- result - Variable in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- result - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverOperationWithResult
-
- result - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- result - Variable in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
- result - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.LongSumReducer
-
- result - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- result - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner.HFileDeleteTask
-
- result - Variable in class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- result - Variable in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait.ProcedureFuture
-
- result - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- Result() - Constructor for enum org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
-
- result - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
- result - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- result - Variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- result - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrContext
-
- Result94Deserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization.Result94Deserializer
-
- ResultBoundedCompletionService<V> - Class in org.apache.hadoop.hbase.client
-
A completion service for the RpcRetryingCallerFactory.
- ResultBoundedCompletionService(RpcRetryingCallerFactory, Executor, int) - Constructor for class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- ResultBoundedCompletionService.QueueingFuture<T> - Class in org.apache.hadoop.hbase.client
-
- resultCache - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- resultCache - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- resultCache(ScanResultCache) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- resultCache - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- ResultDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultDeserializer
-
- resultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
TResult
(Thrift) from a
Result
(HBase).
- resultFromThrift(TResult) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- ResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- ResultGenerator() - Constructor for class org.apache.hadoop.hbase.rest.ResultGenerator
-
- ResultHasher() - Constructor for class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- resultListener - Variable in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- resultListener - Variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- resultListener - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- resultMaxVersions - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
-
- resultObtained - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- results - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- results - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- results - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Result array.
- results - Variable in class org.apache.hadoop.hbase.client.MultiResponse
-
- results - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.CellScanner
-
- Results(ResultScanner) - Constructor for class org.apache.hadoop.hbase.master.http.MetaBrowser.Results
-
- results - Variable in class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
-
- results - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- results - Variable in class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- results - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- results - Variable in class org.apache.hadoop.hbase.rest.TableScanResource
-
- ResultScanner - Interface in org.apache.hadoop.hbase.client
-
Interface for client-side scanning.
- resultScanner - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser.Results
-
- resultScanner - Variable in class org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
-
- ResultScannerWrapper(ResultScanner, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
-
- ResultSerialization - Class in org.apache.hadoop.hbase.mapreduce
-
- ResultSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- ResultSerialization.Result94Deserializer - Class in org.apache.hadoop.hbase.mapreduce
-
The following deserializer class is used to load exported file of 0.94
- ResultSerialization.ResultDeserializer - Class in org.apache.hadoop.hbase.mapreduce
-
- ResultSerialization.ResultSerializer - Class in org.apache.hadoop.hbase.mapreduce
-
- ResultSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultSerializer
-
- resultSet - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- resultSet - Variable in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
- resultsFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
Result
s (HBase) into a list of
TResult
s (Thrift).
- resultsFromThrift(List<TResult>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- resultSize2CacheSize(long) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- resultSize2CacheSize(long) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- ResultStatsUtil - Class in org.apache.hadoop.hbase.client
-
Statistics update about a server/region
- ResultStatsUtil() - Constructor for class org.apache.hadoop.hbase.client.ResultStatsUtil
-
- resume() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
-
Resume the scan.
- resume() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- resume(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- resume(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- resumePrefetch() - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- resumer - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- resumer - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- retain() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- retain() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Increase its reference count, and only when no reference we can free the object's memory.
- retain() - Method in class org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
-
- retain() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- retain(int) - Method in interface org.apache.hadoop.hbase.nio.HBaseReferenceCounted
-
- retain() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
- retain() - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- retain(int) - Method in class org.apache.hadoop.hbase.nio.RefCnt
-
- retain() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Generates a bulk assignment startup plan, attempting to reuse the existing assignment
information from META, but adjusting for the specified list of available/online servers
available for assignment.
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Assign regions to the previously hosting region server nn * @return List of plans
- retainAssignment(Map<RegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- retainByWAL() - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- retainedRegionRWRequestsCnt - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- retcode - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- retCodeDetails - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- retCodeDetails - Variable in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- rethrow(Throwable) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
If we could propagate the given error
directly, we will fill the stack trace with the
current thread's stack trace so it is easier to trace where is the exception thrown.
- rethrowEofException(IOException) - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- rethrowException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- rethrowException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- rethrowException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowException() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- rethrowIfInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
Throw InterruptedIOException if t was an interruption, nothing otherwise.
- retries - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- retries - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- retries - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker.ServerErrors
-
- retries - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- retries - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- retries - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- retries - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient.ZKTask
-
- retries2Attempts(int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Return retires + 1.
- RETRIES_BY_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
-
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails
after a bunch of retries.
- RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
-
Data structure that allows adding more info around Throwable incident.
- RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
-
This subclass of
RetriesExhaustedException
is thrown when
we have more information about which rows were causing which exceptions on what servers.
- RetriesExhaustedWithDetailsException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- RetriesExhaustedWithDetailsException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- retrieveClusterId() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- retrieveFromFile(int[]) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- retrieveGroupListFromGroupTable() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- retrieveGroupListFromZookeeper() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- retrievePassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- Retry() - Constructor for enum org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.Retry
-
- RETRY_ATTEMPTS_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
-
Retrying we multiply hbase.client.pause setting by what we have in this array until we run out
of array items.
- RETRY_ON_IO_EXCEPTION - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
-
- RETRY_ON_IO_EXCEPTION - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- RETRY_SLEEP_INTERVAL_KEY - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- RETRY_TIMER - Static variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- retryConfig - Variable in class org.apache.hadoop.hbase.util.RetryCounter
-
- RetryConfig() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- RetryConfig(int, long, long, TimeUnit, RetryCounter.BackoffPolicy) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- retryConfig - Variable in class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- retryCounter - Variable in class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
-
- retryCounter - Variable in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
-
- retryCounter - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.FileLockCallable
-
Deprecated.
- RetryCounter - Class in org.apache.hadoop.hbase.util
-
Operation retry accounting.
- RetryCounter(int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
-
- RetryCounter(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
-
- RetryCounter.BackoffPolicy - Class in org.apache.hadoop.hbase.util
-
Policy for calculating sleeping intervals between retry attempts
- RetryCounter.ExponentialBackoffPolicy - Class in org.apache.hadoop.hbase.util
-
- RetryCounter.ExponentialBackoffPolicyWithLimit - Class in org.apache.hadoop.hbase.util
-
- RetryCounter.RetryConfig - Class in org.apache.hadoop.hbase.util
-
Configuration for a retry counter
- retryCounterFactory - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- retryCounterFactory - Variable in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
- RetryCounterFactory - Class in org.apache.hadoop.hbase.util
-
- RetryCounterFactory(int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- RetryCounterFactory(int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- RetryCounterFactory(int, int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- RetryCounterFactory(RetryCounter.RetryConfig) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- retryCounterFactory - Variable in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- retryDespiteFastFailMode - Variable in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- RetryImmediatelyException - Exception in org.apache.hadoop.hbase
-
- RetryImmediatelyException(String) - Constructor for exception org.apache.hadoop.hbase.RetryImmediatelyException
-
- retryImmediatelySupported - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- retryImmediatelySupported - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- RetryingCallable<T> - Interface in org.apache.hadoop.hbase.client
-
A Callable<T> that will be retried.
- retryingCaller - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- retryingCallerFactory - Variable in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- RetryingCallerInterceptor - Class in org.apache.hadoop.hbase.client
-
This class is designed to fit into the RetryingCaller class which forms the central piece of
intelligence for the client side retries for most calls.
- RetryingCallerInterceptor() - Constructor for class org.apache.hadoop.hbase.client.RetryingCallerInterceptor
-
- RetryingCallerInterceptorContext - Class in org.apache.hadoop.hbase.client
-
- RetryingCallerInterceptorContext() - Constructor for class org.apache.hadoop.hbase.client.RetryingCallerInterceptorContext
-
- RetryingCallerInterceptorFactory - Class in org.apache.hadoop.hbase.client
-
- RetryingCallerInterceptorFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RetryingCallerInterceptorFactory
-
- RetryingRPC(ScannerCallable) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- RetryingRpcCallable(RpcRetryingCallerFactory, RetryingCallable<V>, int) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RetryingRpcCallable
-
- RetryingTimeTracker - Class in org.apache.hadoop.hbase.client
-
Tracks the amount of time remaining for an operation.
- RetryingTimeTracker() - Constructor for class org.apache.hadoop.hbase.client.RetryingTimeTracker
-
- retryInQueue - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- retryIntervalMs - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- retryOrThrow(RetryCounter, E, String, String) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- retryOrThrow(RetryCounter, KeeperException, String) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- retryPauseTime - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- retryRequest(IOException, int, HttpContext) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.DelayRetryHandler
-
- retryStartup - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncRegionLocator
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- retryTimer - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- RETURN_RESULTS - Static variable in class org.apache.hadoop.hbase.client.Mutation
-
- returnAndEvictBlock(BlockCache, BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- returnBlocks(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- ReturnCode() - Constructor for enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
-
- ReturnCode() - Constructor for enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
- returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- returnExistingWithCast(MutableMetric, Class<T>, String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- returnImmediately - Variable in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- returnImmediately() - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- returnResult - Variable in class org.apache.hadoop.hbase.rest.RowResource
-
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
-
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
-
- returnToNextScreen() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
-
- ReusableGzipOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- ReusableStreamGzipCodec - Class in org.apache.hadoop.hbase.io.compress
-
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression streams.
- ReusableStreamGzipCodec() - Constructor for class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
-
- ReusableStreamGzipCodec.ReusableGzipOutputStream - Class in org.apache.hadoop.hbase.io.compress
-
A bridge that wraps around a DeflaterOutputStream to make it a CompressionOutputStream.
- ReusableStreamGzipCodec.ReusableGzipOutputStream.ResetableGZIPOutputStream - Class in org.apache.hadoop.hbase.io.compress
-
- reusedChunkCount - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
- reverse - Variable in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- reverse() - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- reversed - Variable in class org.apache.hadoop.hbase.client.Scan
-
- reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
-
- reversed - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- ReversedClientScanner - Class in org.apache.hadoop.hbase.client
-
A reversed client scanner which support backward scanning
- ReversedClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedClientScanner
-
Create a new ReversibleClientScanner for the specified table Note that the passed
Scan
's start row maybe changed.
- ReversedKeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
-
ReversedKeyValueHeap is used for supporting reversed scanning.
- ReversedKeyValueHeap(List<? extends KeyValueScanner>, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
nnn
- ReversedKeyValueHeap.ReversedKVScannerComparator - Class in org.apache.hadoop.hbase.regionserver
-
In ReversedKVScannerComparator, we compare the row of scanners' peek values first, sort bigger
one before the smaller one.
- ReversedKVScannerComparator(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap.ReversedKVScannerComparator
-
Constructor n
- ReversedMobStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed
scanning in both the memstore and the MOB store.
- ReversedMobStoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- reverseDNS(InetAddress) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- reverseDNSCacheMap - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
The reverse DNS lookup cache mapping: IPAddress => HostName
- ReversedRegionScannerImpl - Class in org.apache.hadoop.hbase.regionserver
-
ReversibleRegionScannerImpl extends from RegionScannerImpl, and is used to support reversed
scanning.
- ReversedRegionScannerImpl(Scan, List<KeyValueScanner>, HRegion, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedRegionScannerImpl
-
- ReversedRowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.ReversedRowRange
-
- ReversedScannerCallable - Class in org.apache.hadoop.hbase.client
-
A reversed ScannerCallable which supports backward scanning.
- ReversedScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- ReversedStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
- ReversedStoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- ReversedStoreScanner(Scan, ScanInfo, NavigableSet<byte[]>, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Constructor for testing.
- revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Revokes user specific permissions
- revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Revokes user specific permissions
- revoke(UserPermission) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- revoke(UserPermission) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- revoke(UserPermission) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- revoke(RpcController, AccessControlProtos.RevokeRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- revoke(RpcController, AccessControlProtos.RevokeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- revoke(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revokes the permission on the table
- revoke(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revokes the permission on the namespace for the specified user.
- revoke(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Revoke global permissions for the specified user.
- revoke(RpcController, AccessControlProtos.RevokeRequest, RpcCallback<AccessControlProtos.RevokeResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- revoke(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlUtil
-
- revoke(UserPermission) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- revokeAcl(UserPermission, Set<String>, Set<TableName>) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Remove acl when grant or revoke user permission
- rewind() - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- rewind() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set position to beginning of given block
- rewind() - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- rewind() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Rewinds this ByteBuff and the position is set to 0
- rewind() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Rewinds this MBB and the position is set to 0
- rewind() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- rewindThenToList(ByteBuffer, boolean, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- rewriteAsPb(FileSystem, Path, Path, ClusterId) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
nn
- rewriteCellTags(Map<byte[], List<Cell>>, Mutation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Possibly rewrite incoming cell tags.
- riComparator - Variable in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- right - Variable in class org.apache.hadoop.hbase.master.janitor.MetaFixer.Either
-
- right - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- RING_BUFFER_SLOT_COUNT - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- RING_BUFFER_SLOT_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- RingBufferEnvelope - Class in org.apache.hadoop.hbase.namequeues
-
An envelope to carry payload in the ring buffer that serves as online buffer to provide latest
events
- RingBufferEnvelope() - Constructor for class org.apache.hadoop.hbase.namequeues.RingBufferEnvelope
-
- ringBufferEventHandler - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This fellow is run by the above appendExecutor service but it is all about batching up appends
and syncs; it may shutdown without cleaning out the last few appends or syncs.
- RingBufferEventHandler(int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- RingBufferExceptionHandler() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferExceptionHandler
-
- ringBufferSlotCount - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- ringBufferSlotCount(int) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- ringBufferSlotCount() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- RingBufferTruck - Class in org.apache.hadoop.hbase.regionserver.wal
-
A 'truck' to carry a payload across the ring buffer from Handler to WAL.
- RingBufferTruck() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck
-
- RingBufferTruck.Type - Enum in org.apache.hadoop.hbase.regionserver.wal
-
- RIT_CHORE_INTERVAL_MSEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- RIT_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_COUNT_OVER_THRESHOLD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_COUNT_OVER_THRESHOLD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_DURATION_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_DURATION_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_OLDEST_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- RIT_OLDEST_AGE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- ritChore - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- ritCount - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- ritCountOverThresholdGauge - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- ritDuration - Variable in class org.apache.hadoop.hbase.master.RegionState
-
- ritDurationHisto - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- ritGauge - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- ritMap - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- ritOldestAgeGauge - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- ritsOverThreshold - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- ritThreshold - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- rLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- rLength - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- rlength - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- rlength - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- rlength - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- rlength - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- rlock - Variable in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- rlock - Variable in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- rmbuilder - Variable in class org.apache.hadoop.hbase.util.RegionMover
-
- RMI_CONNECTOR_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
-
- RMI_REGISTRY_PORT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.JMXListener
-
- rmiRegistry - Variable in class org.apache.hadoop.hbase.JMXListener
-
- rms - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- rms - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- rms - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- rng - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- rng - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- rng - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- rng - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- RNG - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- RNG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
- RNG_ALGORITHM_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
-
- RNG_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.Cipher
-
- rngAlgorithm - Variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- rngAlgorithm - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAES
-
- rOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- rOffset - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- roffset - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- roffset - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- roffset - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- roffset - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- ROLL_ERRORS_TOLERATED - Static variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- ROLL_ON_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- ROLL_PERIOD_MS_KEY - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
-
- ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- ROLL_RETRIES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- ROLL_THRESHOLD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- rollback(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.FailedProcedure
-
- rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The code to undo what was done by the execute() code.
- rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
-
- rollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- rollbackCloseRegionsForMerge(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Rollback close regions
- rollbackDeleteDirectory(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
undo delete directory
- rollbackStack - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Map the the procId returned by submitProcedure(), the Root-ProcID, to the RootProcedureState.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.GCMergedRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.GCMergedRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.GCRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.MergeTableRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
To rollback
MergeTableRegionsProcedure
, two AssignProcedures are asynchronously
submitted for each region to be merged (rollback doesn't wait on the completion of the
AssignProcedures) .
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.MoveRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.SplitTableRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
To rollback
SplitTableRegionProcedure
, an AssignProcedure is asynchronously submitted
for parent region to be split (rollback doesn't wait on the completion of the AssignProcedure)
.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.RegionStateTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.CloneSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.InitMetaState) - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyTableDescriptorState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.RecoverMetaState) - Method in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ReopenTableRegionsState) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.RestoreSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.SplitWALState) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.SwitchRpcThrottleState) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.PeerModificationState) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- rollbackState(TEnvironment, TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
called to perform the rollback of the specified state
- rollbackState(MasterProcedureEnv, MasterProcedureProtos.ModifyStoreFileTrackerState) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- rollbacRemoveNamespaceQuota(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
undo remove quota for the namespace
- RollController(WAL) - Constructor for class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
-
- rollCurrentKey() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- ROLLING_UPGRADE_CHORE_DELAY_SECONDS_KEY - Static variable in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- ROLLING_UPGRADE_CHORE_PERIOD_SECONDS_KEY - Static variable in class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- rollingPeriod - Variable in class org.apache.hadoop.hbase.util.RollingStatCalculator
-
- rollingSplit(TableName, RegionSplitter.SplitAlgorithm, Configuration) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
- RollingStatCalculator - Class in org.apache.hadoop.hbase.util
-
This class maintains mean and variation for any sequence of input provided to it.
- RollingStatCalculator(int) - Constructor for class org.apache.hadoop.hbase.util.RollingStatCalculator
-
Creates a RollingStatCalculator with given number of rolling periods.
- rollingStatsForCacheMisses - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- rollingStatsForEvictions - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- rollingStatsForFlushes - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- rollingStatsForTunerSteps - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- rollingUpgradeChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RollingUpgradeChore - Class in org.apache.hadoop.hbase.master.migrate
-
To avoid too many migrating/upgrade threads to be submitted at the time during master
initialization, RollingUpgradeChore handles all rolling-upgrade tasks.
- RollingUpgradeChore(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- RollingUpgradeChore(Configuration, ProcedureExecutor<MasterProcedureEnv>, TableDescriptors, Stoppable) - Constructor for class org.apache.hadoop.hbase.master.migrate.RollingUpgradeChore
-
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- rollOnSyncNs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- rollPeriod - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- rollPeriodMs - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- rollPeriodMs(long) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- rollPeriodMs() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- rollRequest - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
-
- rollRequested - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- RollRequestReason() - Constructor for enum org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
- rollRetries - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollThreshold - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollWaitTimeout - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- rollWal(long) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller.RollController
-
- rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Roll the log writer.
- rollWALWriter(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Roll the log writer.
- rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- rollWALWriter(RpcController, AdminProtos.RollWALWriterRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Roll the WAL writer of the region server.
- rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- rollWALWriterImpl(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- rollWriter() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollWriter(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- rollWriter(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- rollWriter() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- rollWriter(boolean) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- rollWriter() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rollWriter(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Roll the log writer.
- rollWriterForTesting() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rollWriterInternal(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- rollWriterLock - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
This lock makes sure only one log roll runs at a time.
- rollWriterWithRetries() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- rootBlockContainingKey(byte[], int, int, CellComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootBlockContainingKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootBlockContainingKey(byte[], int, int, CellComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
-
- rootBlockContainingKey(byte[], int, int, CellComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- rootBlockContainingKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
-
- rootChunk - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
While the index is being written, this represents the current block index referencing all
leaf blocks, with one exception.
- rootCount - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- rootDir - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- rootDir - Variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- rootdir - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- rootDir - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rootDir - Variable in class org.apache.hadoop.hbase.master.SplitWALManager
-
- rootDir - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- rootDir - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- rootDir - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- rootdir - Variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- rootDir - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- rootFs - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rootFs - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- rootFs - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- rootFs - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- rootFS - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- rootIndexHitCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- rootIndexMissCount - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- rootIndexSizeKB - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- rootIndexSizeKB - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- rootLevelIndexSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- rootLevelIndexSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- RootProcedureState<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
Internal state of the ProcedureExecutor that describes the state of a "Root Procedure".
- RootProcedureState() - Constructor for class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- RootProcedureState.State - Enum in org.apache.hadoop.hbase.procedure2
-
- rootProcId - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- RootResource - Class in org.apache.hadoop.hbase.rest
-
- RootResource() - Constructor for class org.apache.hadoop.hbase.rest.RootResource
-
Constructor n
- rotateLeft(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
- rotateRight(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
- roundInt2(int) - Static method in class org.apache.hadoop.hbase.io.compress.CompressionUtil
-
Round up to the next power of two, unless the value would become negative (ints are signed), in
which case just return Integer.MAX_VALUE.
- roundRobin(List<InputSplit>) - Method in class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
Spread the splits list so as to avoid clumping on RegionServers.
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin
assignment.
- roundRobinAssignment(BalancerClusterState, List<RegionInfo>, List<ServerName>, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Round robin a list of regions to a list of servers
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Perform a Round Robin assignment of regions.
- roundRobinAssignment(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- roundRobinAssignmentImpl(FavoredNodeAssignmentHelper, Map<ServerName, List<RegionInfo>>, List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- RoundRobinPool(int) - Constructor for class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- RoundRobinTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Process the return from super-class
TableInputFormat
(TIF) so as to undo any clumping of
InputSplit
s around RegionServers.
- RoundRobinTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
-
- roundSize(long, int) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- roundUp(long, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
- roundUp(long, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
- roundUpToBucketSizeInfo(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Round up the given block size to bucket size, and get the corresponding BucketSizeInfo
- row - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.LocateRequest
-
- row - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- row(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- row - Variable in class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
-
- row - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
- row - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate
-
- row - Variable in class org.apache.hadoop.hbase.client.Cursor
-
- row - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample.Params
-
- row - Variable in class org.apache.hadoop.hbase.client.Get
-
- row - Variable in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateWithFilterBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- row - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateWithFilterBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- row - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
- row - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- row - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- row - Variable in class org.apache.hadoop.hbase.client.Result
-
- Row - Interface in org.apache.hadoop.hbase.client
-
Has a row.
- row - Variable in class org.apache.hadoop.hbase.client.RowMutations
-
- row - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
-
- row - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
-
- row - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
-
- row - Variable in class org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
-
- row - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- row - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- row - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
The row which the user wants to specify and print all the KeyValues for.
- row - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- row - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- row - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowDeleteFamilyCell
-
- row - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- row - Variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- Row - Variable in class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- row - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- ROW_BEFORE_FIRST_RANGE - Static variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- ROW_KEY - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- ROW_KEY_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- ROW_KEYS_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- ROW_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the row length field in bytes
- ROW_LOCK_READ_LOCK_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- ROW_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- ROW_READS_ONLY_ON_MEMSTORE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- ROW_READS_ONLY_ON_MEMSTORE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- RowAccess<T> - Interface in org.apache.hadoop.hbase.client
-
Provide a way to access the inner buffer.
- rowAdjust - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- rowArray - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowCell
-
- rowArray - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowCell
-
- RowBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROW bloom related context.
- RowBloomContext(BloomFilterWriter, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.RowBloomContext
-
- RowBloomHashKey - Class in org.apache.hadoop.hbase.util
-
- RowBloomHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.RowBloomHashKey
-
- rowBuff - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.FirstOnRowByteBufferExtendedCell
-
- rowBuff - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.LastOnRowByteBufferExtendedCell
-
- RowColBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROWCOL bloom related context.
- RowColBloomContext(BloomFilterWriter, CellComparator) - Constructor for class org.apache.hadoop.hbase.util.RowColBloomContext
-
- RowColBloomHashKey - Class in org.apache.hadoop.hbase.util
-
An hash key for ROWCOL bloom.
- RowColBloomHashKey(Cell) - Constructor for class org.apache.hadoop.hbase.util.RowColBloomHashKey
-
- rowComparator - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Row comparator for the region this query is for
- rowComparisonLength - Variable in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- rowcount - Variable in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- rowcount - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- RowCountEndpoint - Class in org.apache.hadoop.hbase.coprocessor.example
-
Sample coprocessor endpoint exposing a Service interface for counting rows and key values.
- RowCountEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
- RowCounter - Class in org.apache.hadoop.hbase.mapred
-
A job with a map to count rows.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
-
- RowCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a just a map phase to count rows.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- RowCounter.RowCounterCommandLineParser - Class in org.apache.hadoop.hbase.mapreduce
-
- RowCounter.RowCounterMapper - Class in org.apache.hadoop.hbase.mapred
-
Mapper that runs the count.
- RowCounter.RowCounterMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Mapper that runs the count.
- RowCounter.RowCounterMapper.Counters - Enum in org.apache.hadoop.hbase.mapred
-
- RowCounter.RowCounterMapper.Counters - Enum in org.apache.hadoop.hbase.mapreduce
-
Counter enumeration to count the actual rows.
- RowCounterCommandLineParser() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterCommandLineParser
-
- RowCounterMapper() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper
-
- RowCounterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterMapper
-
- rowEndKeyComparator - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor.SplitParentFirstComparator
-
- RowEndKeyComparator() - Constructor for class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- rowEquals(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
Compare two keys for equality.
- RowFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the key.
- RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
- RowFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- rowFilter - Variable in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- rowI - Variable in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- RowIndexCodecV1 - Class in org.apache.hadoop.hbase.io.encoding
-
Store cells following every row's start offset, so we can binary search to a row's cells.
- RowIndexCodecV1() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
-
- RowIndexCodecV1.RowIndexEncodingState - Class in org.apache.hadoop.hbase.io.encoding
-
- RowIndexEncoderV1 - Class in org.apache.hadoop.hbase.io.encoding
-
- RowIndexEncoderV1(DataOutputStream, HFileBlockDefaultEncodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
-
- RowIndexEncodingState() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1.RowIndexEncodingState
-
- RowIndexSeekerV1 - Class in org.apache.hadoop.hbase.io.encoding
-
- RowIndexSeekerV1(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- RowIndexSeekerV1.SeekerState - Class in org.apache.hadoop.hbase.io.encoding
-
- rowInverse - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- rowIsInRange(RegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Determines if the specified row is within the row range specified by the specified RegionInfo
- rowIsInRange(RegionInfo, byte[], int, short) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- rowKey - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- ROWKEY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- rowKeyColumnIndex - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- rowLen - Variable in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- rowLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- rowLen - Variable in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- rowLen - Variable in class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
- rowLen - Variable in class org.apache.hadoop.hbase.SizeCachedKeyValue
-
- rowLen - Variable in class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
-
- rowLength - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- rowLength - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- rowLength - Variable in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- rowLength - Variable in class org.apache.hadoop.hbase.util.RowColBloomHashKey
-
- rowLengthWithSize - Variable in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- rowLengthWithSize - Variable in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- rowLimitPerSplit - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- RowLockContext(HashedBytes) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- RowLockImpl(HRegion.RowLockContext, Lock) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- rowLockWaitDuration - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- RowModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a row.
- RowModel() - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Default constructor
- RowModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(String, List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(byte[], List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowMutations - Class in org.apache.hadoop.hbase.client
-
Performs multiple mutations atomically on a single row.
- RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
- RowMutations(byte[], int) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Create an atomic mutation for the specified row.
- rowMutationsFromHBase(RowMutations) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- rowMutationsFromThrift(TRowMutations) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
RowMutations
(HBase) from a
TRowMutations
(Thrift)
- rowNumber - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- rowOffsets - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- rowOfLastPartialResult - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- rowPrefix - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- rowPrefixes - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- RowPrefixFixedLengthBloomContext - Class in org.apache.hadoop.hbase.util
-
Handles ROWPREFIX bloom related context.
- RowPrefixFixedLengthBloomContext(BloomFilterWriter, CellComparator, int) - Constructor for class org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
-
- RowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Interface in org.apache.hadoop.hbase.regionserver
-
- RowProcessorClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
Convenience class that is used to make RowProcessorEndpoint invocations.
- RowProcessorClient() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
-
- rowProcessorExecutor - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- rowProcessorTimeout - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- RowRange() - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- RowRange(String, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
If the startRow is empty or null, set it to HConstants.EMPTY_BYTE_ARRAY, means begin at the
start row of the table.
- RowRange(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- rowRangeList - Variable in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- RowResource - Class in org.apache.hadoop.hbase.rest
-
- RowResource(TableResource, String, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.RowResource
-
Constructor nnnnnn
- rowResultFromHBase(Result[], boolean) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on an Hbase RowResult
object.
- rowResultFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on an array of Hbase
RowResult objects.
- rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- RowResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- RowResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- rows - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- rows - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- rows - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- rows - Variable in class org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
-
- rows - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- rows - Variable in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- rows - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- rowsAccepted - Variable in class org.apache.hadoop.hbase.filter.PageFilter
-
- rowsCovered - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- rowSizeBytes - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- rowSizeCols - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- rowSizeWarnThreshold - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Row size threshold for multi requests above which a warning is logged
- rowSizeWarnThreshold - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Row size threshold for multi requests above which a warning is logged
- rowsOffsetBAOS - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
-
- rowspec - Variable in class org.apache.hadoop.hbase.rest.RowResource
-
- RowSpec - Class in org.apache.hadoop.hbase.rest
-
Parses a path based row/column/timestamp specification into its component elements.
- RowSpec(String) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowSpec(byte[], byte[], byte[][], long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowSpec(byte[], byte[], Collection<byte[]>, long, long, int, Collection<String>) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowSpec(byte[], byte[], Collection<byte[]>, long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowTooBigException - Exception in org.apache.hadoop.hbase.client
-
Gets or Scans throw this exception if running without in-row scan flag set and row size appears
to exceed max configured size (configurable via hbase.table.max.rowsize).
- RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.client.RowTooBigException
-
- RowTooBigException - Exception in org.apache.hadoop.hbase.regionserver
-
- RowTooBigException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RowTooBigException
-
Deprecated.
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- rowToStr(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
n * byte array representing a row in HBase
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- RowTracker() - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter.RowTracker
-
- rowTransform - Variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
- rowUpperLimit - Variable in class org.apache.hadoop.hbase.AsyncMetaTableAccessor.MetaTableScanResultConsumer
-
- RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for RPAREN
- RPC_CALLS_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- RPC_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting RPC codec class name
- RPC_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- RPC_FULL_SCAN_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_FULL_SCAN_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_GET_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_GET_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The first four bytes of Hadoop RPC connections
- RPC_METHOD - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- RPC_MULTI_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_MULTI_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_MUTATE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_MUTATE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_RETRIES_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- RPC_SCAN_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_SCAN_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RPC_SERVICE - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- RPC_SYSTEM - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- RPC_THROTTLE_ZNODE - Static variable in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
- RPC_THROTTLE_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
- RPC_WARN_TIME_KEY - Static variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- rpcCall() - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
Run the RPC call.
- rpcCall(Descriptors.MethodDescriptor, Message, Message, HBaseRpcController, MasterProtos.MasterService.Interface) - Method in class org.apache.hadoop.hbase.client.MasterCoprocessorRpcChannelImpl
-
- rpcCall() - Method in class org.apache.hadoop.hbase.client.MultiServerCallable
-
- rpcCall(Descriptors.MethodDescriptor, Message, Message, HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- rpcCall() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
Run the RPC call.
- rpcCall(Descriptors.MethodDescriptor, Message, Message, HBaseRpcController, ClientProtos.ClientService.Interface) - Method in class org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
-
- rpcCall(int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- rpcCall() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable
-
- rpcCall() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- RpcCall - Interface in org.apache.hadoop.hbase.ipc
-
Interface of all necessary to carry out a RPC method invocation on the server.
- rpcCall - Variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- rpcCall - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
- RpcCallback - Interface in org.apache.hadoop.hbase.ipc
-
Denotes a callback action that has to be executed at the end of an Rpc Call.
- rpcCallback - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
-
Interface of all necessary to carry out a RPC service invocation on the server.
- rpcCallerFactory - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- rpcCallerFactory - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- rpcCallerFactory - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- rpcCallerFactory - Variable in class org.apache.hadoop.hbase.client.HTable
-
- rpcCallerFactory - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannel
-
- RpcChannelImplementation(AbstractRpcClient<?>, Address, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
-
- rpcClient - Variable in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- rpcClient - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- rpcClient - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- rpcClient - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
-
- rpcClient - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- rpcClient - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- RpcClient - Interface in org.apache.hadoop.hbase.ipc
-
Interface for RpcClient implementations so ConnectionManager can handle it.
- rpcClient - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- RpcClientFactory - Class in org.apache.hadoop.hbase.ipc
-
- RpcClientFactory() - Constructor for class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Private Constructor
- RpcConnection - Class in org.apache.hadoop.hbase.ipc
-
Base class for ipc connection.
- RpcConnection(Configuration, HashedWheelTimer, ConnectionId, String, boolean, Codec, CompressionCodec, MetricsConnection) - Constructor for class org.apache.hadoop.hbase.ipc.RpcConnection
-
- rpcConnectionFailure(String, IOException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
The connection to the rest of the procedure group (members and coordinator) has been
broken/lost/failed.
- RpcConnectionRegistry - Class in org.apache.hadoop.hbase.client
-
Rpc based connection registry.
- RpcConnectionRegistry(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RpcConnectionRegistry
-
- rpcController - Variable in class org.apache.hadoop.hbase.client.MasterCallable
-
- rpcController - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
This is 99% of the time a HBaseRpcController but also used doing Coprocessor Endpoints and in
this case, it is a ServerRpcControllable which is not a HBaseRpcController.
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.HBaseHbck
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.HTable
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- RpcControllerFactory - Class in org.apache.hadoop.hbase.ipc
-
- RpcControllerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- rpcCount - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- rpcCounters - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- RpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
- RpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- RpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- RpcExecutor.CallPriorityComparator - Class in org.apache.hadoop.hbase.ipc
-
Comparator used by the "normal callQueue" if DEADLINE_CALL_QUEUE_CONF_KEY is set to true.
- rpcFactory - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- rpcFullScanRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- rpcGetRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- RpcHandler - Class in org.apache.hadoop.hbase.ipc
-
Thread to handle rpc call.
- RpcHandler(String, double, int, BlockingQueue<CallRunner>, AtomicInteger, AtomicInteger, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RpcHandler
-
- rpcHistograms - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- RpcLogDetails - Class in org.apache.hadoop.hbase.namequeues
-
RpcCall details that would be passed on to ring buffer of slow log responses
- RpcLogDetails(RpcCall, Message, String, long, String, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- rpcMultiRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- rpcMutateRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- rpComparator - Variable in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- rpcPreCheck(String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks for the following pre-checks in order:
Master is initialized
Rpc caller has admin permissions
- rpcPreCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Checks for the following pre-checks in order:
RegionServer is running
If authorization is enabled, then RPC caller has ADMIN permissions
- rpcQueueTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- RpcResponse - Interface in org.apache.hadoop.hbase.ipc
-
An interface represent the response of an rpc call.
- RpcRetryingCallable<V> - Class in org.apache.hadoop.hbase.client
-
A RetryingCallable for RPC connection operations.
- RpcRetryingCallable() - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- RpcRetryingCaller<T> - Interface in org.apache.hadoop.hbase.client
-
- RpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
-
- RpcRetryingCallerFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- RpcRetryingCallerFactory(Configuration, RetryingCallerInterceptor) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- rpcRetryingCallerFactory - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- rpcRetryingCallerFactory - Variable in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- rpcRetryingCallerFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rpcRetryingCallerFactory - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- RpcRetryingCallerImpl<T> - Class in org.apache.hadoop.hbase.client
-
- RpcRetryingCallerImpl(long, long, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- RpcRetryingCallerImpl(long, long, int, RetryingCallerInterceptor, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- RpcRetryingCallerWithReadReplicas - Class in org.apache.hadoop.hbase.client
-
Caller that goes to replica if the primary region does no answer within a configurable timeout.
- RpcRetryingCallerWithReadReplicas(RpcControllerFactory, TableName, ClusterConnection, Get, ExecutorService, int, int, int, int) - Constructor for class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- RpcRetryingCallerWithReadReplicas.ReplicaRegionServerCallable - Class in org.apache.hadoop.hbase.client
-
A RegionServerCallable that takes into account the replicas, i.e.
- rpcs - Variable in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- rpcs - Variable in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
- rpcs - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- rpcScanRequestCount - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- RpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
An interface for RPC request scheduling algorithm.
- RpcScheduler() - Constructor for class org.apache.hadoop.hbase.ipc.RpcScheduler
-
- RpcScheduler.Context - Class in org.apache.hadoop.hbase.ipc
-
Exposes runtime information of a RpcServer
that a RpcScheduler
may need.
- RpcSchedulerContext - Class in org.apache.hadoop.hbase.ipc
-
- RpcSchedulerContext(RpcServer) - Constructor for class org.apache.hadoop.hbase.ipc.RpcSchedulerContext
-
n
- RpcSchedulerFactory - Interface in org.apache.hadoop.hbase.regionserver
-
- rpcServer - Variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- rpcServer - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServerPreambleHandler
-
- rpcServer - Variable in class org.apache.hadoop.hbase.ipc.RpcSchedulerContext
-
- RpcServer - Class in org.apache.hadoop.hbase.ipc
-
An RPC server that hosts protobuf described Services.
- RpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer
-
Constructs a server listening on the named port and address.
- rpcServer - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- rpcServer - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- RpcServer.BlockingServiceAndInterface - Class in org.apache.hadoop.hbase.ipc
-
Datastructure for passing a BlockingService
and its associated class of protobuf
service interface.
- RpcServer.CallCleanup - Interface in org.apache.hadoop.hbase.ipc
-
- RpcServerFactory - Class in org.apache.hadoop.hbase.ipc
-
- RpcServerFactory() - Constructor for class org.apache.hadoop.hbase.ipc.RpcServerFactory
-
Private Constructor
- RpcServerInterface - Interface in org.apache.hadoop.hbase.ipc
-
- rpcServices - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- rpcServices - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rpcStartTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- RpcSystem() - Constructor for enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.RpcSystem
-
- rpcTasks - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- rpcThrottleEnabled - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- rpcThrottleEnabled - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- rpcThrottleEnabled - Variable in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- rpcThrottleEnabled - Variable in class org.apache.hadoop.hbase.replication.regionserver.SwitchRpcThrottleRemoteCallable
-
- rpcThrottleStorage - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- rpcThrottleStorage - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- rpcThrottleStorage - Variable in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- RpcThrottleStorage - Class in org.apache.hadoop.hbase.quotas
-
ZK based rpc throttle storage.
- RpcThrottleStorage(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
- rpcThrottleZNode - Variable in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
- rpcThrottlingException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- rpcThrottlingException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- RpcThrottlingException - Exception in org.apache.hadoop.hbase.quotas
-
Describe the throttling result.
- RpcThrottlingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- RpcThrottlingException(RpcThrottlingException.Type, long, String) - Constructor for exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
-
- RpcThrottlingException.Type - Enum in org.apache.hadoop.hbase.quotas
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- rpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- rpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
-
- rpcTimeout - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
The RPC timeout period (milliseconds)
- rpcTimeoutMs - Variable in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
-
- rpcTimeoutMs - Variable in class org.apache.hadoop.hbase.client.HTable
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- rpcTimeoutNs - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorRpcChannelImpl
-
- rpcTimers - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- RPCTInfoGetter - Class in org.apache.hadoop.hbase.ipc
-
Used to extract a tracing Context
from an instance of TracingProtos.RPCTInfo
.
- RPCTInfoGetter() - Constructor for class org.apache.hadoop.hbase.ipc.RPCTInfoGetter
-
- rpcWarnTime - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- rqs - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- rs - Variable in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
-
- rs - Variable in class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
-
- rs - Variable in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
- RS_COPROC_METRICS_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- RS_COPROC_METRICS_DESCRIPTION - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- RS_COPROC_METRICS_JMX_CONTEXT - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- RS_COPROC_METRICS_NAME - Static variable in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- RS_ENABLE_SERVER_QUERY_METER_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_ENABLE_SERVER_QUERY_METER_METRICS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_ENABLE_TABLE_METRICS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_ENABLE_TABLE_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_ENABLE_TABLE_QUERY_METER_METRICS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_ENABLE_TABLE_QUERY_METER_METRICS_KEY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- RS_GROUP_MAPPING_SCRIPT - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupMappingScript
-
- RS_GROUP_MAPPING_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupMappingScript
-
- RS_HOSTNAME_DISABLE_MASTER_REVERSEDNS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- RS_HOSTNAME_KEY - Static variable in class org.apache.hadoop.hbase.util.DNS
-
- RS_RPC_RETRY_INTERVAL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- RS_RPC_STARTUP_WAIT_TIME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- RS_START_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- RS_START_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- rsAccounting - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- rsAdmins - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
Map of admin interfaces per registered regionserver; these interfaces we use to control
regionservers out on the cluster
- RSDumpServlet - Class in org.apache.hadoop.hbase.regionserver.http
-
- RSDumpServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
-
- rsFatals - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RSGROUP_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- RSGROUP_TABLE_DESC - Static variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
Table descriptor for hbase:rsgroup
catalog table
- RSGROUP_TABLE_NAME - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- RSGROUP_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- RSGroupableBalancer - Interface in org.apache.hadoop.hbase.rsgroup
-
Marker Interface.
- RSGroupAdmin - Interface in org.apache.hadoop.hbase.rsgroup
-
Group user API interface used between client and server.
- RSGroupAdminClient - Class in org.apache.hadoop.hbase.rsgroup
-
Client used for managing region server group information.
- RSGroupAdminClient(Connection) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- RSGroupAdminEndpoint - Class in org.apache.hadoop.hbase.rsgroup
-
- RSGroupAdminEndpoint() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- RSGroupAdminEndpoint.RSGroupAdminServiceImpl - Class in org.apache.hadoop.hbase.rsgroup
-
Implementation of RSGroupAdminService defined in RSGroupAdmin.proto.
- RSGroupAdminServer - Class in org.apache.hadoop.hbase.rsgroup
-
Service to support Region Server Grouping (HBase-6721).
- RSGroupAdminServer(MasterServices, RSGroupInfoManager) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- RSGroupAdminServiceImpl() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
-
- RSGroupBasedLoadBalancer - Class in org.apache.hadoop.hbase.rsgroup
-
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does
region balance based on a table's group membership.
- RSGroupBasedLoadBalancer() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- rsGroupGetRegionsInTransition(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- rsGroupHasOnlineServer(MasterServices, RSGroupInfo) - Static method in class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
-
- rsgroupHasServersOnline(TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- RSGroupInfo - Class in org.apache.hadoop.hbase.rsgroup
-
Stores the group information of region server groups.
- RSGroupInfo(String) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- RSGroupInfo(String, Set<Address>) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- RSGroupInfo(String, Set<Address>, Set<TableName>) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- RSGroupInfo(RSGroupInfo) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- rsGroupInfoManager - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
-
- rsGroupInfoManager - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- RSGroupInfoManager - Interface in org.apache.hadoop.hbase.rsgroup
-
Interface used to manage RSGroupInfo storage.
- RSGroupInfoManagerImpl - Class in org.apache.hadoop.hbase.rsgroup
-
This is an implementation of
RSGroupInfoManager
which makes use of an HBase table as the
persistence store for the group information.
- RSGroupInfoManagerImpl(MasterServices) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- RSGroupInfoManagerImpl.RSGroupMappingScript - Class in org.apache.hadoop.hbase.rsgroup
-
- RSGroupInfoManagerImpl.RSGroupStartupWorker - Class in org.apache.hadoop.hbase.rsgroup
-
- RSGroupInfoManagerImpl.ServerEventsListenerThread - Class in org.apache.hadoop.hbase.rsgroup
-
- RSGroupMajorCompactionTTL - Class in org.apache.hadoop.hbase.rsgroup
-
This script takes an rsgroup as argument and compacts part/all of regions of that table based on
the table's TTL.
- RSGroupMajorCompactionTTL() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
-
- rsGroupMap - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- RSGroupMappingScript(Configuration) - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupMappingScript
-
- rsgroupMappingScript - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupMappingScript
-
- RSGroupProtobufUtil - Class in org.apache.hadoop.hbase.rsgroup
-
- RSGroupProtobufUtil() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupProtobufUtil
-
- rsGroupStartupWorker - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- RSGroupStartupWorker() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupStartupWorker
-
- RSGroupTableAccessor - Class in org.apache.hadoop.hbase
-
Read rs group information from hbase:rsgroup
.
- RSGroupTableAccessor() - Constructor for class org.apache.hadoop.hbase.RSGroupTableAccessor
-
- RSGroupUtil - Class in org.apache.hadoop.hbase.rsgroup
-
Helper class for RSGroup implementation
- RSGroupUtil() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupUtil
-
- rsGroupZNode - Static variable in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- rsHost - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rsinfo - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.WorkItemRegion
-
Deprecated.
- rsListStorage - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- RSMobFileCleanerChore - Class in org.apache.hadoop.hbase.mob
-
The class RSMobFileCleanerChore for running cleaner regularly to remove the obsolete (files which
have no active references to) mob files that were referenced from the current RS.
- RSMobFileCleanerChore(HRegionServer) - Constructor for class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
-
- RSMobFileCleanerChore() - Constructor for class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
-
- rsMobFileCleanerChore - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rsObserverGetter - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- rspmHost - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rsPorts - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- rsPorts(List<Integer>) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
-
- rsPorts - Variable in class org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
-
Ports that RegionServer should use.
- rsProcClass - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ServerOperation
-
- rsProcData - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ServerOperation
-
- RSProcedureCallable - Interface in org.apache.hadoop.hbase.procedure2
-
A general interface for a sub procedure runs at RS side.
- RSProcedureDispatcher - Class in org.apache.hadoop.hbase.master.procedure
-
A remote procecdure dispatcher for regionservers.
- RSProcedureDispatcher(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- RSProcedureDispatcher.DeadRSRemoteCall - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.ExecuteProceduresRemoteCall - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.RegionCloseOperation - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.RegionOpenOperation - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.RegionOperation - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.RemoteProcedureResolver - Interface in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureDispatcher.ServerOperation - Class in org.apache.hadoop.hbase.master.procedure
-
- RSProcedureHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
A event handler for running procedure.
- RSProcedureHandler(HRegionServer, long, RSProcedureCallable) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.RSProcedureHandler
-
- rsQuotaManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rsReportExecutor - Variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- rsReportHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- rsReportQueueSize - Variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- rsReports - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- rsRpcRetryInterval - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- rsRpcServices - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
Used to get details for scan with a scanner_id
TODO try to figure out a better way and remove reference from regionserver package later.
- RSRpcServices - Class in org.apache.hadoop.hbase.regionserver
-
Implements the regionserver RPC services.
- RSRpcServices(HRegionServer) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- RSRpcServices.RegionScannerCloseCallBack - Class in org.apache.hadoop.hbase.regionserver
-
An Rpc callback for closing a RegionScanner.
- RSRpcServices.RegionScannerHolder - Class in org.apache.hadoop.hbase.regionserver
-
Holder class which holds the RegionScanner, nextCallSeq and RpcCallbacks together.
- RSRpcServices.RegionScannersCloseCallBack - Class in org.apache.hadoop.hbase.regionserver
-
An RpcCallBack that creates a list of scanners that needs to perform callBack operation on
completion of multiGets.
- RSRpcServices.RegionScannerShippedCallBack - Class in org.apache.hadoop.hbase.regionserver
-
An Rpc callback for doing shipped() call on a RegionScanner.
- RSRpcServices.ScannerListener - Class in org.apache.hadoop.hbase.regionserver
-
Instantiated as a scanner lease.
- rsRsreportMaxQueueLength - Variable in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- rss - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- rss - Variable in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- rss - Variable in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- rss - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- rsServices - Variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- rsServices - Variable in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- rsServices - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- rsServices - Variable in class org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
Deprecated.
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessors
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
The region server services
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
-
- rsServices - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- rsSpaceQuotaManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rssStub - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rsStartupWaitTime - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- RSStatusServlet - Class in org.apache.hadoop.hbase.regionserver.http
-
- RSStatusServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
-
- rsStubs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- rsSupportsOffline - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- rsWrap - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- rulesPath - Variable in class org.apache.hadoop.hbase.master.balancer.HeterogeneousRegionCountCostFunction
-
- run() - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- run() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
- run() - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.SingleServerRequestRunnable
-
- run() - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner.PrefetchRunnable
-
- run() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.AsyncClientExample
-
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.BufferedMutatorExample
-
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
-
- run(String[]) - Method in class org.apache.hadoop.hbase.client.example.RefreshHFilesClient
-
- run() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker
-
- run() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService.QueueingFuture
-
- run() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- run(String[]) - Method in class org.apache.hadoop.hbase.hbtop.HBTop
-
- run() - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- run(String[]) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
- run() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.StatisticsThread
-
- run() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.WriterThread
-
- run(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
Runs the command-line pretty-printer, and returns the desired command exit code (zero for
success, non-zero for failure).
- run() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.EvictionThread
-
- run() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.StatisticsThread
-
- run() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
- run() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.StatisticsThread
-
- run(R) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
Called on completion of the RPC call with the response object, or null
in the case of
an error.
- run() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
Reads the call from the queue, write them on the socket.
- run() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- run() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- run(R) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback
-
Called on completion of the RPC call with the response object, or null
in the case of
an error.
- run() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler.FifoCallRunner
-
- run(boolean) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
-
- run() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallback
-
- run() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- run(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- run() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
-
- run() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl.JitteredRunnableScheduledFuture
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Export
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.Import
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
- run(String, Map<byte[], List<Path>>, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.MapRunner
-
- run(Mapper<ImmutableBytesWritable, Result, K2, V2>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Run the application's maps using a thread pool.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
Main entry point.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- run() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- run() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- run(String[]) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.master.MasterInitializationMonitor
-
- run() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- run() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- run() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.DeadRSRemoteCall
-
- run() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- run() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- run() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer.ClientZkUpdater
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
-
Main method for the tool.
- run() - Method in class org.apache.hadoop.hbase.mob.MobFileCache.EvictionThread
-
- run() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor.MonitorRunnable
-
- run() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- run() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
-
- run() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
-
- run(String[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALPrettyPrinter
-
Deprecated.
Pass one or more log file names and formatting options and it will dump out a text version of
the contents on stdout
.
- run() - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool.StatisticsThread
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore.InMemoryCompactionRunnable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The HRegionServer sticks in this loop until closed.
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.SystemExitWhenAbortTimeout
-
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushHandler
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionServerMetricsWrapperRunnable
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl.HRegionMetricsWrapperRunnable
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.TableMetricsWrapperRunnable
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerCloseCallBack
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerShippedCallBack
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.ShutdownHook.DoNothingThread
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.ShutdownHook.ShutdownHookThread
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- run() - Method in interface org.apache.hadoop.hbase.regionserver.StoreEngine.IOExceptionRunnable
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues
-
- run() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication.ReplicationStatisticsTask
-
- run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- run() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- run() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
Runs the REST server.
- run() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.RSGroupStartupWorker
-
- run() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- run(String[]) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
-
- run() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- run() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
- run() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- run() - Method in class org.apache.hadoop.hbase.thrift.DemoClient
-
- run() - Method in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- run() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.ClientConnnection
-
Loops on processing a client forever
- run() - Method in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet.HttpKerberosServerAction
-
- run() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Run without any command line arguments
- run(String[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- run() - Method in class org.apache.hadoop.hbase.thrift2.DemoClient
-
- run() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- run() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- run() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
-
- run(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- run() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperMonitor
-
- run(Path, TableName) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- run(String, TableName) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Perform bulk load on the given table.
- run(Map<byte[], List<Path>>, TableName) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Perform bulk load on the given table.
- run(String[]) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- run(String[]) - Method in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- run() - Method in interface org.apache.hadoop.hbase.trace.TraceUtil.ThrowingRunnable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- run() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
-
- run() - Method in class org.apache.hadoop.hbase.util.FSRegionScanner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HBaseFsckTool
-
Deprecated.
- run() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor.Monitor
-
- run() - Method in class org.apache.hadoop.hbase.util.LossyCounting.SweepRunnable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- run() - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- run() - Method in class org.apache.hadoop.hbase.wal.OutputSink.WriterThread
-
- run(String[]) - Static method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Pass one or more log file names and formatting options and it will dump out a text version of
the contents on stdout
.
- run() - Method in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- run(String[]) - Method in class org.apache.hadoop.hbase.zookeeper.ZKAclReset
-
- run() - Method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster.JmxCacheBusterRunnable
-
- RUN_MAX_STEPS_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- RUN_SHUTDOWN_HOOK - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for boolean configuration whose default is true.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- runAsLoginUser(PrivilegedExceptionAction<T>) - Static method in class org.apache.hadoop.hbase.security.User
-
Executes the given action as the login user
- runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Ask for a scan of the catalog table.
- runCatalogJanitor() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for a scan of the catalog table.
- runCatalogJanitor() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- runCatalogJanitor() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- runCatalogJanitor() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- runCatalogJanitor() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- runCatalogScan() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- runCatalogScan(RpcController, MasterProtos.RunCatalogScanRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- runChore() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
Request execution of this chore's action.
- runCleaner() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Ask for cleaner chore to run.
- runCleanerChore() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Ask for cleaner chore to run.
- runCleanerChore() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- runCleanerChore() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- runCleanerChore() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- runCleanerChore(RpcController, MasterProtos.RunCleanerChoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- runCleanerChore() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- runCmdAsync(List<String>) - Static method in class org.apache.hadoop.hbase.util.ProcessUtils
-
- runCmdLine() - Method in class org.apache.hadoop.hbase.zookeeper.ZKMainServer.HACK_UNTIL_ZOOKEEPER_1897_ZooKeeperMain
-
Run the command-line args passed.
- runCoprocessorAction(MasterProcedureEnv, MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Coprocessor Action.
- runCoprocessorAction(MasterProcedureEnv, MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Coprocessor Action.
- runCoprocessorAction(MasterProcedureEnv, MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
Coprocessor Action.
- runCopyJob(Path, Path, String, Path, boolean, String, String, int, int, int) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Run Map-Reduce Job to perform the files copy.
- runEviction() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Multi-threaded call to run the eviction process.
- runEviction() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Multi-threaded call to run the eviction process.
- runHbckChore() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- runHbckChore() - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Request HBCK chore to run at master side.
- runHbckChore(RpcController, MasterProtos.RunHbckChoreRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- runMaxSteps - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- runMonitor(String[]) - Method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- runnable - Variable in class org.apache.hadoop.hbase.client.DelayingRunner
-
- runnable - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- runnable - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- runnable - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
-
- runnables - Variable in class org.apache.hadoop.hbase.master.procedure.Queue
-
- runnables - Variable in class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- runnerStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- RunnerStats(MetricRegistry) - Constructor for class org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
-
- running - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorStatus
-
- running - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.TrackingThreadPoolExecutor
-
- running - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- running - Variable in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- running - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This flag is used to indicate to sub threads when they should go down.
- running - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- running - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- running - Variable in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
When running, the "snapshot" may be changed when this round's checking finish.
- running - Variable in class org.apache.hadoop.hbase.monitoring.TaskMonitor.MonitorRunnable
-
- running - Variable in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- running - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- running - Variable in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- running - Variable in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- running - Variable in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- running - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- running - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- running - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- RunningEventStatus(Thread, EventHandler) - Constructor for class org.apache.hadoop.hbase.executor.ExecutorService.RunningEventStatus
-
- runningProcCount - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- runProcedure() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
-
- runReplicationBarrierCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- runReplicationBarrierCleaner() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Run the ReplicationBarrierChore.
- runShippedCallback(RSRpcServices.RegionScannerHolder) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- runtimeInconsistencyFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- runUnixMXBeanMethod(String) - Method in class org.apache.hadoop.hbase.util.JVM
-
Load the implementation of UnixOperatingSystemMXBean for Oracle jvm and runs the desired
method.
- runWithoutRpcCall(Runnable) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
Insert procedure may be called by master's rpc call.
- runZKServer(QuorumPeerConfig) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
- RWQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
-
RPC Executor that uses different queues for reads and writes.
- RWQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- s - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- safeClose(ChannelOutboundInvoker) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Close the channel and eat the returned future by logging the error when the future is completed
with error.
- safeDispose(SaslClient) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
- safeDispose(SaslServer) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
- safeGetHeapMemoryUsage() - Static method in class org.apache.hadoop.hbase.io.util.MemorySizeUtil
-
Return JVM memory statistics while properly handling runtime exceptions from the JVM.
- safePointAttained() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Called by Thread B when it attains the 'safe point'.
- safePointAttainedLatch - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Count down this latch when safe point attained.
- safePointReleasedLatch - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
Latch to wait on.
- safePointWaiter - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
Object to block on while waiting on safe point.
- SafePointZigZagLatch() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SafePointZigZagLatch
-
- safeStopTrackingTable(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Stop tracking a table.
- safeWrite(ChannelOutboundInvoker, Object) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Call write on the channel and eat the returned future by logging the error when the future is
completed with error.
- safeWriteAndFlush(ChannelOutboundInvoker, Object) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
-
Call writeAndFlush on the channel and eat the returned future by logging the error when the
future is completed with error.
- sameAsPreviousTS(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- sameAsPreviousTSAndType(long, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- sameFile(FileStatus, FileStatus) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
Check if the two files are equal by looking at the file length, and at the checksum (if user
has specified the verifyChecksum flag).
- SampleItem(long, int, int) - Constructor for class org.apache.hadoop.metrics2.util.MetricSampleQuantiles.SampleItem
-
- samples - Variable in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Current list of sampled items, maintained in sorted order with error bounds
- SampleUploader - Class in org.apache.hadoop.hbase.mapreduce
-
Sample Uploader MapReduce
- SampleUploader() - Constructor for class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
- SampleUploader.Uploader - Class in org.apache.hadoop.hbase.mapreduce
-
- sanitize(String) - Static method in class org.apache.hadoop.hbase.http.ProfileOutputServlet
-
- sanityCheck() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Checks if the block is internally consistent, i.e.
- sanityCheck(Cell) - Method in class org.apache.hadoop.hbase.util.BloomContext
-
- sanityCheck() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- sanityCheck(Configuration, TableDescriptor) - Static method in class org.apache.hadoop.hbase.util.TableDescriptorChecker
-
Checks whether the table conforms to some sane limits, and configured values (compression, etc)
work.
- sanityCheckAssertion(long, long, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- sanityCheckAssertion(BlockType, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- sanityCheckConfigs() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- sanityCheckLeft(byte[], Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the first KV is within multi-writer range.
- sanityCheckRight(byte[], Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the last KV is within multi-writer range.
- sanityCheckUncompressed() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
An additional sanity-check in case no compression or encryption is being used.
- SASL_ADAPTOR - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- SASL_AUTH_METHOD - Static variable in class org.apache.hadoop.hbase.security.provider.DigestSaslAuthenticationProvider
-
- SASL_AUTH_METHOD - Static variable in class org.apache.hadoop.hbase.security.provider.GssSaslAuthenticationProvider
-
- SASL_AUTH_METHOD - Static variable in class org.apache.hadoop.hbase.security.provider.SimpleSaslAuthenticationProvider
-
- SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- SASL_TRANSFER_MAGIC_NUMBER - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- SaslAuthenticationProvider - Interface in org.apache.hadoop.hbase.security.provider
-
Encapsulation of client-side logic to authenticate to HBase via some means over SASL.
- SaslAuthMethod - Class in org.apache.hadoop.hbase.security.provider
-
- SaslAuthMethod(String, byte, String, UserGroupInformation.AuthenticationMethod) - Constructor for class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
- SaslChallengeDecoder - Class in org.apache.hadoop.hbase.security
-
Decode the sasl challenge sent by RpcServer.
- SaslChallengeDecoder() - Constructor for class org.apache.hadoop.hbase.security.SaslChallengeDecoder
-
- saslClient - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- saslClient - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslUnwrapHandler
-
- saslClient - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslWrapHandler
-
- saslClient - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- saslClient - Variable in class org.apache.hadoop.hbase.security.SaslUnwrapHandler
-
- saslClient - Variable in class org.apache.hadoop.hbase.security.SaslWrapHandler
-
- SaslClientAuthenticationProvider - Interface in org.apache.hadoop.hbase.security.provider
-
Encapsulation of client-side logic to authenticate to HBase via some means over SASL.
- SaslClientAuthenticationProviders - Class in org.apache.hadoop.hbase.security.provider
-
Accessor for all SaslAuthenticationProvider instances.
- SaslClientAuthenticationProviders(Collection<SaslClientAuthenticationProvider>, AuthenticationProviderSelector) - Constructor for class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- SaslClientCallbackHandler(String, char[]) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslClientCallbackHandler
-
Creates a new SaslClientCallbackHandler.
- saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Do client side SASL authentication with server via the given InputStream and OutputStream
- saslContextEstablished - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, AtomicReference<UserGroupInformation>) - Constructor for class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider.SaslDigestCallbackHandler
-
- SaslGssCallbackHandler() - Constructor for class org.apache.hadoop.hbase.security.provider.GssSaslServerAuthenticationProvider.SaslGssCallbackHandler
-
- saslInputStream - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- saslMech - Variable in class org.apache.hadoop.hbase.security.provider.SaslAuthMethod
-
- saslNegotiate(Channel) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- SaslNegotiateHandler(Configuration, String, char[], Map<String, String>, int, Promise<Void>, DFSClient) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- saslOutputStream - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- SaslPlainServer - Class in org.apache.hadoop.hbase.security.provider.example
-
This class was copied from Hadoop Common (3.1.2) and subsequently modified.
- SaslPlainServer(CallbackHandler) - Constructor for class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
-
- SaslPlainServer.SaslPlainServerFactory - Class in org.apache.hadoop.hbase.security.provider.example
-
- SaslPlainServer.SecurityProvider - Class in org.apache.hadoop.hbase.security.provider.example
-
- SaslPlainServerFactory() - Constructor for class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer.SaslPlainServerFactory
-
- saslPromise - Variable in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
- saslPromise - Variable in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- saslProps - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- saslProps - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- saslProps - Variable in class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
-
- saslProviders - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- saslQop - Variable in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- saslReadAndProcess(ByteBuff) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- saslRpcClient - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- saslRpcClient - Variable in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- saslServer - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- saslServer - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- saslServer - Variable in class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
-
- SaslServerAuthenticationProvider - Interface in org.apache.hadoop.hbase.security.provider
-
Encapsulates the server-side logic to authenticate a client over SASL.
- SaslServerAuthenticationProviders - Class in org.apache.hadoop.hbase.security.provider
-
- SaslServerAuthenticationProviders(Configuration, HashMap<Byte, SaslServerAuthenticationProvider>) - Constructor for class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
- SaslStatus - Enum in org.apache.hadoop.hbase.security
-
- SaslStatus(int) - Constructor for enum org.apache.hadoop.hbase.security.SaslStatus
-
- SaslUnwrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslUnwrapHandler
-
- SaslUnwrapHandler - Class in org.apache.hadoop.hbase.security
-
Unwrap sasl messages.
- SaslUnwrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslUnwrapHandler
-
- SaslUtil - Class in org.apache.hadoop.hbase.security
-
- SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
-
- SaslUtil.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
-
- SaslWrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslWrapHandler
-
- SaslWrapHandler - Class in org.apache.hadoop.hbase.security
-
wrap sasl messages.
- SaslWrapHandler(SaslClient) - Constructor for class org.apache.hadoop.hbase.security.SaslWrapHandler
-
- satisfies(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- satisfies(boolean, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- satisfies(boolean, byte[], int, int, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- SatisfiesCode() - Constructor for enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.SatisfiesCode
-
- satisfiesNoUnsafe(boolean, byte[], int, int, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- save() - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Snapshot a map of the current identifiers to class names for reconstruction on reading out of a
file.
- saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Save metadata in HFile which will be written to disk
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- sawFailedSanityCheck() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ObservedExceptionsInBatch
-
- sawNoSuchFamily() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ObservedExceptionsInBatch
-
- sawWrongRegion() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ObservedExceptionsInBatch
-
- sc - Variable in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- scale(double, double, double, double, double) - Static method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
Scale valueIn in the range [baseMin,baseMax] to the range [limitMin,limitMax]
- scale(double, double, double) - Static method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
Scale the value between 0 and 1.
- SCALE_BASE - Static variable in class org.apache.hadoop.hbase.Size
-
- scan - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- scan - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scan - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- scan(Scan, C) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
The scan API uses the observer pattern.
- scan(Scan, ScanResultConsumer) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- scan - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- scan(Scan, AdvancedScanResultConsumer) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- Scan - Class in org.apache.hadoop.hbase.client
-
Used to perform Scan operations.
- Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation across all rows.
- Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Creates a new instance of this class while copying all values.
- Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Builds a scan object with the same specs as get.
- scan - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scan - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper
-
- scan - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- scan - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Holds the details for the internal scanner.
- scan - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- scan - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- scan - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- scan - Variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
The scan object may be null but the serialized form of scan is never null or empty since we
serialize the scan object with default values then.
- scan() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
Run janitorial scan of catalog hbase:meta
table looking for garbage to collect.
- scan - Variable in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- scan(HBaseRpcController, ClientProtos.ScanRequest, RSRpcServices.RegionScannerHolder, long, int, int, List<Result>, ClientProtos.ScanResponse.Builder, MutableObject<Object>, RpcCall) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Scan data in a table.
- scan - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- scan - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- Scan.ReadType - Enum in org.apache.hadoop.hbase.client
-
- scan0(Scan, ScanResultConsumer) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
- SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set the maximum number of values to return for each call to next().
- SCAN_CACHE_BLOCKS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set to false to disable server-side caching of blocks for this scan.
- SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The number of rows for caching that will be passed to scanners.
- SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Column Family to Scan
- SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Space delimited list of columns and column families to scan.
- SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FOR_COMPACTION - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_LIMIT_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_LIMIT_MAX - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_LIMIT_PARAM - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The maximum number of version to return.
- SCAN_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- SCAN_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- SCAN_REGION_STATE_PARAM - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_REVERSED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan start row
- SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan stop row
- SCAN_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- SCAN_SIZE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SCAN_START_PARAM - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_TABLE_PARAM - Static variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- SCAN_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
-
- SCAN_TIME_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The ending timestamp used to filter columns with a specific range of versions.
- SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The starting timestamp used to filter columns with a specific range of versions.
- SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The timestamp used to filter columns with a specific timestamp.
- SCAN_VTIME_WEIGHT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
Used to control the scan delay, currently sqrt(numNextCall * weight)
- scanAll(Scan) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
-
Return all the results that match the given scan object.
- scanAll(Scan) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
-
- scanAll(Scan) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- scanBalancer - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- scanBatch - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- scanByRegionEncodedName(Connection, String) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Scans META table for a row whose key contains the specified regionEncodedName, returning
a single related Result
instance if any row is found, null otherwise.
- ScanControllerImpl(Optional<Cursor>) - Constructor for class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- ScanControllerState() - Constructor for enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState
-
- ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
This class is responsible for the tracking and enforcement of Deletes during the course of a Scan
operation.
- ScanDeleteTracker(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
-
- scanExhausted() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- scanForMergedParentRegions() - Method in class org.apache.hadoop.hbase.master.hbck.HbckChore
-
Scan hbase:meta to get set of merged parent regions, this is a very heavy scan.
- scanForReport() - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
Scan hbase:meta.
- scanFromHBase(Scan) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- scanFromThrift(TScan) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- scanHandlersCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- scanHandlerStack - Variable in class org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
-
- scanInfo - Variable in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- scanInfo - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- ScanInfo - Class in org.apache.hadoop.hbase.regionserver
-
Immutable information for scans over a store.
- ScanInfo(Configuration, ColumnFamilyDescriptor, long, long, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- ScanInfo(Configuration, byte[], int, int, long, KeepDeletedCells, long, long, CellComparator, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
n * @param family Name of this store's column family
- ScanInfo(byte[], int, int, long, KeepDeletedCells, long, CellComparator, long, boolean, long, boolean, long, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- scanKeysValues(Path, HFilePrettyPrinter.KeyValueStatsCollector, HFileScanner, byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- ScanLabelGenerator - Interface in org.apache.hadoop.hbase.security.visibility
-
This would be the interface which would be used add labels to the RPC context and this would be
stored against the UGI.
- scanLabelGenerators - Variable in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- scanLimit - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- scanMeta(AsyncTable<AdvancedScanResultConsumer>, TableName, MetaTableAccessor.QueryType, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Performs a scan of META table for given table.
- scanMeta(AsyncTable<AdvancedScanResultConsumer>, byte[], byte[], MetaTableAccessor.QueryType, int, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
Performs a scan of META table for given table.
- scanMeta(Connection, TableName, MetaTableAccessor.QueryType, int, MetaTableAccessor.Visitor, CatalogReplicaMode) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- scanMeta(Connection, byte[], byte[], MetaTableAccessor.QueryType, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- scanMeta(Connection, MetaTableAccessor.Visitor, TableName, byte[], int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a scan of META table for given table starting from given row.
- scanMeta(Connection, byte[], byte[], MetaTableAccessor.QueryType, int, MetaTableAccessor.Visitor) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Performs a scan of META table.
- scanMeta(Connection, byte[], byte[], MetaTableAccessor.QueryType, Filter, int, MetaTableAccessor.Visitor, CatalogReplicaMode) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- scanMetaForTableRegions(Connection, MetaTableAccessor.Visitor, TableName, CatalogReplicaMode) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- scanMetaForTableRegions(Connection, MetaTableAccessor.Visitor, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
-
Provides metrics related to scan operations (both server side and client side metrics).
- ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
constructor
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScanModifyingObserver - Class in org.apache.hadoop.hbase.coprocessor.example
-
A RegionObserver which modifies incoming Scan requests to include additional columns than what
the user actually requested.
- ScanModifyingObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.ScanModifyingObserver
-
- scanner - Variable in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- scanner - Variable in class org.apache.hadoop.hbase.coprocessor.example.DelegatingInternalScanner
-
- scanner - Variable in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- scanner - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- scanner - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- scanner - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- scanner - Variable in class org.apache.hadoop.hbase.master.region.RegionScannerAsResultScanner
-
- scanner - Variable in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- scanner - Variable in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- scanner - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerCloseCallBack
-
- scanner - Variable in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- scanner - Variable in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
-
- Scanner(Scan) - Constructor for class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- SCANNER_ALREADY_CLOSED - Static variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Deprecated.
- SCANNER_LEASE_EXPIRED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SCANNER_LEASE_EXPIRED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
-
- ScannerCallable - Class in org.apache.hadoop.hbase.client
-
Scanner operations such as create, next, etc.
- ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- ScannerCallable.MoreResults - Enum in org.apache.hadoop.hbase.client
-
- ScannerCallableWithReplicas - Class in org.apache.hadoop.hbase.client
-
This class has the logic for handling scanners for regions with and without replicas.
- ScannerCallableWithReplicas(TableName, ClusterConnection, ScannerCallable, ExecutorService, int, Scan, int, int, int, int, Configuration, RpcRetryingCaller<Result[]>) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- ScannerCallableWithReplicas.RetryingRPC - Class in org.apache.hadoop.hbase.client
-
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerContext - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
-
- ScannerContext - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext(boolean, ScannerContext.LimitFields, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- ScannerContext.Builder - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.LimitFields - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.LimitScope - Enum in org.apache.hadoop.hbase.regionserver
-
The various scopes where a limit can be enforced.
- ScannerContext.NextState - Enum in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.ProgressFields - Class in org.apache.hadoop.hbase.regionserver
-
- scannerFactory - Variable in class org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
-
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerId - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scannerId - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- scannerId - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scannerIdGen - Variable in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
-
- scannerIdGenerator - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- ScannerIdGenerator - Class in org.apache.hadoop.hbase.regionserver
-
Generate a new style scanner id to prevent collision with previous started server or other RSs.
- ScannerIdGenerator(ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
-
- ScannerInstanceResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerInstanceResource() - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- scannerLeaseExpiredCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- scannerLeaseTimeoutPeriod(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scannerLeaseTimeoutPeriod - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
The lease timeout period for client scanners (milliseconds).
- scannerLeaseTimeoutPeriodNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scannerLeaseTimeoutPeriodNs - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- ScannerListener(String) - Constructor for class org.apache.hadoop.hbase.regionserver.RSRpcServices.ScannerListener
-
- scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerMap - Variable in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.HTable
-
- ScannerModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of Scanner parameters.
- ScannerModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Default constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, int, long, int, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, int, long, long, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- ScannerModel.FilterModel - Class in org.apache.hadoop.hbase.rest.model
-
- ScannerModel.FilterModel.ByteArrayComparableModel - Class in org.apache.hadoop.hbase.rest.model
-
- ScannerModel.FilterModel.ByteArrayComparableModel.ComparatorType - Enum in org.apache.hadoop.hbase.rest.model
-
- ScannerModel.FilterModel.FilterType - Enum in org.apache.hadoop.hbase.rest.model
-
- ScannerModel.JaxbJsonProviderHolder - Class in org.apache.hadoop.hbase.rest.model
-
Implement lazily-instantiated singleton as per recipe here:
http://literatejava.com/jvm/fastest-threadsafe-singleton-jvm/
- scannerName - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerShippedCallBack
-
- scannerName - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.ScannerListener
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
-
- scannerOrder - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- scannerOwners - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
Mapping of scanner instances to the user who created them
- scannerOwners - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
Mapping of scanner instances to the user who created them
- scannerReadPoints - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- scannerReadPoints - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- ScannerResetException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the server side has received an Exception, and asks the Client to reset the scanner
state by closing the current region scanner, and reopening from the start of last seen row.
- ScannerResetException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
constructor
- ScannerResetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
Constructor
- ScannerResetException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
- scannerResetException() - Method in interface org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
-
- scannerResetException() - Method in class org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
-
- ScannerResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResource
-
Constructor nn
- ScannerResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- ScannerResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- ScannerResultGenerator(String, RowSpec, Filter, int, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- scanners - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
-
- scanners - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
-
- scanners - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- scanners - Static variable in class org.apache.hadoop.hbase.rest.ScannerResource
-
- scannersForDelayedClose - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- scannersForDelayedClose - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- scannerState - Variable in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- ScanOptions - Interface in org.apache.hadoop.hbase.regionserver
-
This class gives you the ability to change the max versions and TTL options before opening a
scanner for a Store.
- ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
A query matcher that is specifically designed for the scan case.
- ScanQueryMatcher(Cell, ScanInfo, ColumnTracker, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
- ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver.querymatcher
-
- scanReadRpcTimeout - Variable in class org.apache.hadoop.hbase.client.HTable
-
- scanReadRpcTimeout - Variable in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- scanRegionState - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- scanResultCache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScanResultCache - Interface in org.apache.hadoop.hbase.client
-
Used to separate the row constructing logic.
- ScanResultConsumer - Interface in org.apache.hadoop.hbase.client
-
Receives
Result
for an asynchronous scan.
- ScanResultConsumerBase - Interface in org.apache.hadoop.hbase.client
-
The base interface for scan result consumer.
- ScanResumerImpl() - Constructor for class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- ScanResumerState() - Constructor for enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState
-
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- scans - Variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Holds the set of scans used to define the input.
- scanSingleRegion() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
Create retry caller for scanning a region.
- ScanSingleRegionCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scanSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- scanSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- scanStart - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- scanTable - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser
-
- scanTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- scanTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableLatenciesImpl.TableHistograms
-
- scanTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- scanTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scanTimeout - Variable in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- scanTimeout - Variable in class org.apache.hadoop.hbase.client.HTable
-
- scanTimeout - Variable in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- scanTimeoutNs - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- scanTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- ScanType - Enum in org.apache.hadoop.hbase.regionserver
-
Enum to distinguish general scan types.
- ScanType() - Constructor for enum org.apache.hadoop.hbase.regionserver.ScanType
-
- scanUsePread - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- scanVirtualTimeWeight - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Keeps track of the columns for a scan if they are not explicitly specified
- ScanWildcardColumnTracker(int, int, long, CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
Return maxVersions of every row.
- schedLock() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- scheduleAbortTimer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- scheduleChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
Schedule a chore.
- ScheduledChore - Class in org.apache.hadoop.hbase
-
ScheduledChore is a task performed on a period in hbase.
- ScheduledChore() - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int, long) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- ScheduledChore(String, Stoppable, int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
Construct a ScheduledChore
- scheduledChores - Variable in class org.apache.hadoop.hbase.ChoreService
-
Maps chores to their futures.
- scheduleFlush(String, List<byte[]>) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- scheduleFlush(String, List<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- scheduleFlush(String, List<byte[]>) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
-
- scheduleForRetry(IOException) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- scheduleFullRefresh() - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
Refresh all the region locations.
- scheduleIdleScanTask() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- scheduler - Variable in class org.apache.hadoop.hbase.ChoreService
-
This thread pool is used to schedule all of the Chores
- scheduler - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- scheduler - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Scheduler/Queue that contains runnable procedures.
- scheduler - Variable in enum org.apache.hadoop.metrics2.lib.MetricsExecutorImpl.ExecutorSingleton
-
- scheduleRelogin(Throwable) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- scheduleRenewLeaseTask() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- schedulerLock - Variable in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- scheduleSCPsForUnknownServers() - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- scheduleSCPsForUnknownServers() - Method in interface org.apache.hadoop.hbase.client.Hbck
-
- scheduleSCPsForUnknownServers(RpcController, MasterProtos.ScheduleSCPsForUnknownServersRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- scheduleServerCrashProcedure(List<HBaseProtos.ServerName>) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
- scheduleServerCrashProcedure(RpcController, MasterProtos.ScheduleServerCrashProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- scheduleServerCrashProcedures(List<ServerName>) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- scheduleServerCrashProcedures(List<ServerName>) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Statistics thread schedule pool (for heavy debugging, could remove)
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Statistics thread schedule pool (for heavy debugging, could remove)
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Statistics thread schedule pool (for heavy debugging, could remove)
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.mob.MobFileCache
-
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
Statistics thread schedule pool
- scheduleThreadPool - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Statistics thread schedule pool
- scheduleTimeoutTask(Call) - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- schedUnlock() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- schedWaitCond - Variable in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- SCHEMA - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.Options
-
- SchemaLocking - Class in org.apache.hadoop.hbase.master.procedure
-
Locks on namespaces, tables, and regions.
- SchemaLocking(Function<Long, Procedure<?>>) - Constructor for class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- SchemaResource - Class in org.apache.hadoop.hbase.rest
-
- SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
-
Constructor nn
- scope - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- scope - Variable in class org.apache.hadoop.hbase.security.access.Permission
-
- Scope(char) - Constructor for enum org.apache.hadoop.hbase.security.access.Permission.Scope
-
- SCOPE_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- scopeWALEdits(WALKey, WALEdit, Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
Utility method used to set the correct scopes on each log key.
- ScopeWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Keeps KVs that are scoped other than local
- ScopeWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
-
- screen - Variable in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- Screen - Class in org.apache.hadoop.hbase.hbtop.screen
-
This dispatches key presses and timers to the current
ScreenView
.
- Screen(Configuration, long, Mode, List<Field>, Field, Boolean, List<RecordFilter>, long, boolean) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- SCREEN_DESCRIPTION_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
-
- SCREEN_DESCRIPTION_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- SCREEN_DESCRIPTION_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- ScreenBuffer - Class in org.apache.hadoop.hbase.hbtop.terminal.impl
-
Represents a buffer of the terminal screen for double-buffering.
- ScreenBuffer() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- screenBuffer - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- screenBuffer - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- ScreenView - Interface in org.apache.hadoop.hbase.hbtop.screen
-
An interface for a screen view that handles key presses and timers.
- script - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
Get rsgroup table mapping script
- scriptTimeout - Variable in class org.apache.hadoop.hbase.HealthChecker
-
- search(T, int, int, int) - Method in interface org.apache.hadoop.hbase.MetaCellComparator.SearchDelimiter
-
- search(T, int, int, int) - Method in interface org.apache.hadoop.hbase.MetaCellComparator.SearchDelimiterInReverse
-
- searchDelimiterIndex(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Find index of passed delimiter.
- searchDelimiterIndex(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Find index of passed delimiter.
- searchDelimiterIndexInReverse(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Find index of passed delimiter walking from end of buffer backwards.
- searchDelimiterIndexInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Find index of passed delimiter walking from end of buffer backwards.
- searchTreeLevel - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
The number of levels in the block index tree.
- second - Variable in class org.apache.hadoop.hbase.util.ObjectIntPair
-
- second - Variable in class org.apache.hadoop.hbase.util.Pair
-
- second - Variable in class org.apache.hadoop.hbase.util.PairOfSameType
-
- second - Variable in class org.apache.hadoop.hbase.util.Triple
-
- SECONDARY_INDEX_ENTRY_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
The number of bytes stored in each "secondary index" entry in addition to key bytes in the
non-root index block format.
- secondaryIndexOffsetMarks - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunk
-
The "secondary index" used for binary search over variable-length records in a "non-root"
format block.
- secondaryRSToRegionMap - Variable in class org.apache.hadoop.hbase.favored.FavoredNodesManager
-
- secondaryRSToRegionMap - Variable in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- secret - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- secretManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- secretManager - Variable in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider.SaslDigestCallbackHandler
-
- secretManager - Variable in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- secretManager - Variable in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- secure - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
-
- secure - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- secure - Static variable in class org.apache.hadoop.hbase.thrift2.DemoClient
-
- SECURE_RNG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
- SecureAsyncProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureAsyncProtobufLogWriter(EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
-
- SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client
-
Client proxy for SecureBulkLoadProtocol
- SecureBulkLoadClient(Configuration, Table) - Constructor for class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
Securely bulk load a list of HFiles using client protocol.
- secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
Securely bulk load a list of HFiles using client protocol.
- secureBulkLoadHFiles(ClientProtos.ClientService.BlockingInterface, List<Pair<byte[], String>>, byte[], boolean, Token<?>, String, boolean, List<String>, boolean) - Method in class org.apache.hadoop.hbase.client.SecureBulkLoadClient
-
- secureBulkLoadHFiles(HRegion, ClientProtos.BulkLoadHFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- secureBulkLoadHFiles(HRegion, ClientProtos.BulkLoadHFileRequest, List<String>) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- SecureBulkLoadListener(FileSystem, String, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- secureBulkLoadManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- SecureBulkLoadManager - Class in org.apache.hadoop.hbase.regionserver
-
Bulk loads in secure mode.
- SecureBulkLoadManager(Configuration, Connection) - Constructor for class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- SecureBulkLoadManager.SecureBulkLoadListener - Class in org.apache.hadoop.hbase.regionserver
-
- SecureHadoopUser() - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- SecureHadoopUser(UserGroupInformation) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- SecureHadoopUser(UserGroupInformation, LoadingCache<String, String[]>) - Constructor for class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- secureInitAfterHeader(boolean, Encryptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- SecureProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- SecureProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- secureRandom(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes using a strong random number generator.
- secureRandom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes at the specified position using a strong random number
generator.
- secureRootFilePerms - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- secureRootSubDirPerms - Variable in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- SecureWALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
A WALCellCodec that encrypts the WALedits.
- SecureWALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecureWALCellCodec(Configuration, Encryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecureWALCellCodec(Configuration, Decryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecureWALCellCodec.EncryptedKvDecoder - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureWALCellCodec.EncryptedKvEncoder - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecurityCapability - Enum in org.apache.hadoop.hbase.client.security
-
Available security capabilities
- SecurityCapability(int) - Constructor for enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- SecurityConstants - Class in org.apache.hadoop.hbase.security
-
SecurityConstants holds a bunch of kerberos-related constants
- SecurityConstants() - Constructor for class org.apache.hadoop.hbase.security.SecurityConstants
-
- securityEnabled - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- securityEnabled - Variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-
- securityEnabled - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- SecurityHeadersFilter - Class in org.apache.hadoop.hbase.http
-
- SecurityHeadersFilter() - Constructor for class org.apache.hadoop.hbase.http.SecurityHeadersFilter
-
- securityInfo - Variable in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- SecurityInfo - Class in org.apache.hadoop.hbase.security
-
Maps RPC protocol interfaces to required configuration
- SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
-
- SecurityProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer.SecurityProvider
-
- SecurityUtil - Class in org.apache.hadoop.hbase.security
-
Security related generic utility methods.
- SecurityUtil() - Constructor for class org.apache.hadoop.hbase.security.SecurityUtil
-
- seed - Variable in class org.apache.hadoop.hbase.util.Random64
-
- seedUniquifier - Static variable in class org.apache.hadoop.hbase.util.Random64
-
- seedUniquifier() - Static method in class org.apache.hadoop.hbase.util.Random64
-
- seek(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- seek() - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Seeks all scanners at or below the specified seek key.
- seek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at or after the specified KeyValue.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at or after the specified Cell.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- seek() - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- seek(long) - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- seekAllScanner(ScanInfo, List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekAsDirection(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
Do a backwardSeek in a reversed StoreScanner(scan backward)
- seekAsDirection(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Do a reseek in a normal StoreScanner(scan forward) n * @return true if scanner has values left,
false if end of scanner n
- seekAtOrAfter(HFileScanner, Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
nn * @return false if not found or if k is after the end.
- seekBefore(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- seekBefore(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Consider the cell stream of all the cells in the file, c[0] ..
- seekCount - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seeked - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
- seeker - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- SeekerState(ObjectIntPair<ByteBuffer>, boolean) - Constructor for class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- SeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- SeekerStateBufferedEncodedSeeker(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder.SeekerStateBufferedEncodedSeeker
-
- SeekerStateBufferedEncodedSeeker(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder.SeekerStateBufferedEncodedSeeker
-
- seekFirst(TNode) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Reset the iterator, and seeks to the first (min) node of the tree
- seekHintFilters - Variable in class org.apache.hadoop.hbase.filter.FilterListWithAND
-
- seekNext() - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
- 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.
- seekOnMultipleSources(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileUtil
-
guards against NullPointer utility which tries to seek on the DFSIS and will try an alternative
source if the FSDataInputStream throws an NPE HBASE-17501 nnn
- seekOrSkipToNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekOrSkipToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekScanners(List<? extends KeyValueScanner>, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- seekScanners(List<? extends KeyValueScanner>, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Seek the specified scanners with the given key nn * @param isLazy true if using lazy seek
- seekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- seekTo(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
An internal API function.
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
Positions this scanner at the start of the file.
- seekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
SeekTo or just before the passed cell
.
- seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Positions this scanner at the start of the file.
- seekTo(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
Reset the iterator, and seeks to the specified key
- seekToDataBlock(Cell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding, HFile.CachingBlockReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Return the data block which contains this key.
- seekToKeyInBlock(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- seekToKeyInBlock(Cell, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if seekBefore
is false
the last key that is strictly less than the given key if
seekBefore
is true.
- seekToKeyInBlock(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- seekToLastRow() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first KeyValue of last row
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at the first KeyValue of last row
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seekToNewSource(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- seekToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- seekToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekToPreviousRow(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first Cell of the row which is the previous row of specified key
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Seek the scanner at the first Cell of the row which is the previous row of specified key
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seePastDeleteMarkers - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
-
whether time range queries can see rows "behind" a delete
- Segment - Class in org.apache.hadoop.hbase.regionserver
-
This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its
snapshot.
- Segment(CellComparator, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
-
- Segment(CellComparator, List<ImmutableSegment>, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
-
- Segment(CellSet, CellComparator, MemStoreLAB, TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
-
- Segment(Segment) - Constructor for class org.apache.hadoop.hbase.regionserver.Segment
-
- segment - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- segment - Variable in class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- SegmentFactory - Class in org.apache.hadoop.hbase.regionserver
-
A singleton store segment factory.
- SegmentFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SegmentFactory
-
- segments - Variable in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- SegmentScanner - Class in org.apache.hadoop.hbase.regionserver
-
A scanner of a single memstore segment.
- SegmentScanner(Segment, long) - Constructor for class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Scanners are ordered from 0 (oldest) to newest in increasing order.
- segregateRegionsAndAssignRegionsWithFavoredNodes(List<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
-
- segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- select(TableName, byte[], RegionLocateType) - Method in interface org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSelector
-
Select a catalog replica region where client go to loop up the input row key.
- select(TableName, byte[], RegionLocateType) - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
When it looks up a location, it will call this method to find a replica region to go.
- select(List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Called to select files for compaction.
- select(List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine.DateTieredCompactionContext
-
- select(List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine.DefaultCompactionContext
-
- select(StoreFileTrackerProtos.StoreFileList[]) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFile
-
- select(List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine.StripeCompaction
-
- selectClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Selects a ZK client port.
- selectCoHostedRegionPerGroup(Int2IntCounterMap, int[], int[]) - Method in class org.apache.hadoop.hbase.master.balancer.RegionReplicaCandidateGenerator
-
Randomly select one regionIndex out of all region replicas co-hosted in the same group (a group
is a server, host or rack)
- selectCompactFiles(List<HStoreFile>, int, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
Select at least one file in the candidates list to compact, through choosing files from the
head to the index that the accumulation length larger the max compaction size.
- selectCompaction(Collection<HStoreFile>, List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
-
- selectCompaction(Collection<HStoreFile>, List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- selectCompaction(StripeCompactionPolicy.StripeInformationProvider, List<HStoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectCompaction(HRegion, HStore, int, CompactionLifeCycleTracker, CompactSplit.CompactionCompleteTracker, User) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- selectExpiredMergeCompaction(StripeCompactionPolicy.StripeInformationProvider, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectFlush(CellComparator, StripeCompactionPolicy.StripeInformationProvider, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectionTime - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- selectL0OnlyCompaction(StripeCompactionPolicy.StripeInformationProvider) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectMajorCompaction(ArrayList<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- selectMinorCompaction(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
We receive store files sorted in ascending order by seqId then scan the list of files.
- selectModeFieldsAndAddCountField(List<FieldInfo>, List<Record>, Field) - Method in class org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
-
Form new record list with records formed by only fields provided through fieldInfo and add a
count field for each record with value 1 We are doing two operation of selecting and adding new
field because of saving some CPU cycles on rebuilding the record again
- selector - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
-
Deprecated.
- selector - Variable in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- SELECTOR_KEY - Static variable in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
- SELECTOR_NUM_OPTION - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- SELECTOR_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number of selector threads for reading and writing socket
- selectPartitions(Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
Choose partitions between row ranges to hash to a single output file Selects region
boundaries that fall within the scan range, and groups them into the desired number of
partitions.
- selectProvider(String, User) - Method in interface org.apache.hadoop.hbase.security.provider.AuthenticationProviderSelector
-
- selectProvider(String, User) - Method in class org.apache.hadoop.hbase.security.provider.BuiltInProviderSelector
-
- selectProvider(String, User) - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeProviderSelector
-
- selectProvider(String, User) - Method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
-
Chooses the best authentication provider and corresponding token given the HBase cluster
identifier and the user.
- selectProvider(byte) - Method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
-
Selects the appropriate SaslServerAuthenticationProvider from those available.
- selectRegionLocation(HRegionLocation, HRegionLocation, boolean, boolean) - Method in class org.apache.hadoop.hbase.RegionLocations
-
- selectScannersFrom(HStore, List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Filters the given list of scanners using Bloom filter, time range, and TTL.
- selectSimpleCompaction(List<HStoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
Selects the compaction of a single stripe using default policy.
- selectSingleStripeCompaction(StripeCompactionPolicy.StripeInformationProvider, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
-
Returns the stores need to be flushed.
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
Returns the stores need to be flushed.
- selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- semaphore - Variable in class org.apache.hadoop.hbase.ipc.FastPathRpcHandler
-
- send(AsyncNonMetaRegionLocator.LocateRequest) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
-
- sendAbortProcessSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- 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.ZKProcedureCoordinator
-
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.
- sendBufSizePRedictor - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- SendBufSizePredictor - Class in org.apache.hadoop.hbase.io.asyncfs
-
Used to predict the next send buffer size.
- SendBufSizePredictor() - Constructor for class org.apache.hadoop.hbase.io.asyncfs.SendBufSizePredictor
-
- sendCall(Call) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection.CallSender
-
- sendError(HttpServletResponse, int, String) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- sendError(int, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendError(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendError(int, String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Called by the filter after it decides that the request is a potential CSRF attack and
therefore must be rejected.
- sendError(int, String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
- sendForceUpdateSignal(long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- 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.ZKProcedureCoordinator
-
The "acquire" phase.
- sendGlobalBarrierComplete() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendGlobalBarrierReached() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Sends a message to all members that the global barrier condition has been satisfied.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify members that all members have acquired their parts of the barrier and that they can now
execute under the global barrier.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
- sendGlobalBarrierStart() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendLogLevelRequest() - Method in class org.apache.hadoop.hbase.http.log.LogLevel.CLI
-
Send HTTP request to the daemon.
- sendMemberAborted(Subprocedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that we aborted the specified
Subprocedure
- sendMemberAborted(Subprocedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This should be called by the member and should write a serialized root cause exception as to
the abort znode.
- sendMemberAcquired(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has acquired the locally
required barrier condition.
- sendMemberAcquired(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This attempts to create an acquired state znode for the procedure (snapshot name).
- sendMemberCompleted(Subprocedure, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has completed the work that
needed to be done under the global barrier.
- sendMemberCompleted(Subprocedure, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This acts as the ack for a completed procedure
- sendMultiAction(Map<ServerName, MultiAction>, int, List<Action>, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Send a multi action structure to the servers, after a delay depending on the attempt number.
- sendOrDelay(Map<ServerName, AsyncBatchRpcRetryingCaller.ServerRequest>, int) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- sendPostSyncSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
- sendProcedureAddedNotification(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- sendProcedureFinishedNotification(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- sendProcedureLoadedNotification(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- sendRedirect(String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendRegionPlansToRingBuffer(List<RegionPlan>, double, double, String, long) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- sendRegionWarmup(ServerName, RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends a WARMUP RPC to the specified server to warmup the specified region.
- sendRejectionReasonToRingBuffer(String, List<CostFunction>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- sendRequest(Call, HBaseRpcController) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- sendRequest(Call, HBaseRpcController) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- sendRequest(Call, HBaseRpcController) - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- sendRequest(ServerName, AdminProtos.ExecuteProceduresRequest) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- sendRequest0(Call, HBaseRpcController) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- sendRequestsToSecondaryReplicas(Function<Integer, CompletableFuture<T>>, RegionLocations, CompletableFuture<T>, Optional<MetricsConnection>) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.NettyServerCall
-
If we have a response, and delay is not set, then respond immediately.
- sendResponseIfReady() - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Send the response of this RPC call.
- sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.SimpleServerCall
-
Deprecated.
- sendSaslMessage(ChannelHandlerContext, byte[]) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- sendSaslMessage(ChannelHandlerContext, byte[], List<CipherOption>) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
-
- sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
-
- sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.StoppableThread
-
- sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- sendStopSignal() - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
-
- sendToServer(ServerName, AsyncBatchRpcRetryingCaller.ServerRequest, int) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- SENT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- SENT_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- sentBytes(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- sentBytes(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- sentBytes - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- sentBytes(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- sentResponse(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- sentResponse(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- sentResponse(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- SEP - Static variable in class org.apache.hadoop.hbase.mob.MobUtils
-
- SEPARATE_OLDLOGDIR - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
Separate old log into different dir by regionserver name
- SEPARATED_BYTE - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
-
- SEPARATOR - Static variable in class org.apache.hadoop.hbase.backup.HFileArchiver
-
- separator - Variable in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- separator - Variable in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Column seperator
- separator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Column seperator
- separator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Column seperator
- SEPARATOR - Static variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Returns the separator character to use when storing / printing the row
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- separatorByte - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- seperator - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- seq - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
- SEQ_COMPARATOR - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileComparators
-
Comparator that compares based on the Sequence Ids of the the store files.
- SEQ_ID_MAX_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileComparators
-
Comparator for time-aware compaction.
- seqId - Variable in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- seqid - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- seqId - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- seqId - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- seqId - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- seqId - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- seqId - Variable in class org.apache.hadoop.hbase.KeyValue
-
- seqId - Variable in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- seqids - Static variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- seqids - Static variable in class org.apache.hadoop.hbase.executor.ExecutorService.Executor
-
- seqNum - Variable in class org.apache.hadoop.hbase.HRegionLocation
-
- seqNum - Variable in class org.apache.hadoop.hbase.io.crypto.aes.CryptoAES.Integrity
-
- seqNum - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- seqNum - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionInfo
-
- SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- SEQNUM_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- sequence - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
- sequence - Variable in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
- SEQUENCE_ID_FILE_SUFFIX - Static variable in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- SEQUENCE_ID_FILE_SUFFIX_LENGTH - Static variable in class org.apache.hadoop.hbase.wal.WALSplitUtil
-
- sequenceId - Variable in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- sequenceid - Variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
- SequenceId - Interface in org.apache.hadoop.hbase.regionserver
-
Interface which abstracts implementations on log sequenceId assignment
- sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- sequenceId - Variable in class org.apache.hadoop.hbase.util.FSTableDescriptors.SequenceIdAndFileLength
-
- sequenceId - Variable in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
SequenceId for this edit.
- sequenceIdAccounting - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
Class that does accounting of sequenceids in WAL subsystem.
- SequenceIdAccounting - Class in org.apache.hadoop.hbase.regionserver.wal
-
Accounting of sequence ids per region and then by column family.
- SequenceIdAccounting() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- SequenceIdAndFileLength(int, int) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors.SequenceIdAndFileLength
-
- sequenceIdChecker - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- SequentialProcedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
A SequentialProcedure describes one step in a procedure chain:
- SequentialProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- serial - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- serial - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- serialize(byte[], Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.http.gson.ByteArraySerializer
-
- serialize(ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Serializes its data into destination.
- serialize(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Write the trailer to a data stream.
- serialize(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serialize(Cell) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
-
- serialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
Deprecated.
- serialize(Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization.MutationSerializer
-
- serialize(Result) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization.ResultSerializer
-
- serialize(Size, Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.master.http.gson.SizeAsBytesSerializer
-
- serialize(byte[], Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.ByteArraySerializer
-
- serialize(RegionVisualizer.RegionDetails, Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetailsSerializer
-
- serialize(Size, Type, JsonSerializationContext) - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer.SizeAsBytesSerializer
-
- serialize(Message) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureStateSerializer
-
- serialize(Message) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil.CompatStateSerializer
-
- serialize(Message) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil.StateSerializer
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
Converts a RemoteProcedureException to an array of bytes.
- serializeAsPB(DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Write trailer data as protobuf.
- serializeColumnFamilyAttribute(Function<ColumnFamilyDescriptor, String>, List<TableDescriptor>) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- serializeConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Write the configuration to a String n * to write
- serializeConstraintClass(Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
- serializeDelete(long, List<Mutation>, List<byte[]>) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- serializeMobFileRefs(SetMultimap<TableName, String>) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Serialize a set of referenced mob hfiles
- serializePut(Procedure<?>, List<Mutation>, List<byte[]>) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.GCMergedRegionsProcedure
-
Deprecated.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.GCRegionProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
-
Deprecated.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.OpenRegionProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableDescriptorProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.DisablePeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.EnablePeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.RemovePeerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.procedure2.FailedProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The user-level code of the procedure may have some state to persist (e.g.
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
-
- serializeStateData(ProcedureStateSerializer) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
-
- serialReplicateRegionEntries(List<WAL.Entry>, int, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- SerialReplicationChecker - Class in org.apache.hadoop.hbase.replication.regionserver
-
Helper class to determine whether we can push a given WAL entry without breaking the replication
order.
- SerialReplicationChecker(Configuration, ReplicationSource) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- SerialReplicationSourceWALReader - Class in org.apache.hadoop.hbase.replication.regionserver
-
WAL reader for a serial replication peer.
- SerialReplicationSourceWALReader(FileSystem, Configuration, ReplicationSourceLogQueue, long, WALEntryFilter, ReplicationSource, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationSourceWALReader
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.CellComparatorImpl
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.client.NoServerForRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.client.RegionOfflineException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.client.WrongRowIOException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ConcurrentTableModificationException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.MasterStoppedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
Deprecated.
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.FailedCloseWALAfterInitializedErrorException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.HBaseIOException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.conf.ConfServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.HttpServer.StackServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.ProfileOutputServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.NameNodeException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocatorException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ipc.CallCancelledException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.master.http.MasterDumpServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.master.http.MasterRedirectServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.master.http.MasterStatusServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.MasterNotRunningException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.NamespaceExistException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.NamespaceNotFoundException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.NotServingRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.procedure2.ProcedureSuspendedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
-
Deprecated.
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
-
Deprecated.
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
Deprecated.
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.RegionException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.LeaseException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.regionserver.WrongRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.RegionTooBusyException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.replication.regionserver.ReplicationRuntimeException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.replication.regionserver.WALEntryFilterRetryableException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.replication.ReplicationException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ReplicationPeerNotFoundException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.CellModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.NamespacesModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.RowModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.TableModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.rest.RESTServletContainer
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.security.visibility.LabelAlreadyExistsException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.security.visibility.ParseException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.ServerName
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.TableExistsException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.TableNotDisabledException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.TableNotEnabledException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.TableNotFoundException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.UnknownRegionException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.UnknownScannerException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.util.FileSystemVersionException
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.util.Pair
-
- serialVersionUID - Static variable in class org.apache.hadoop.hbase.util.StealJobQueue
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.wal.WALSplitter.CorruptedLogFileException
-
- serialVersionUID - Static variable in exception org.apache.hadoop.hbase.ZooKeeperConnectionException
-
- serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- server - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.SingleServerRequestRunnable
-
- server - Variable in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- server - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- server - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- server - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- server - Variable in class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
-
- server - Variable in class org.apache.hadoop.hbase.master.CachedClusterId
-
- server - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- server(Server) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- server() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
-
- server - Variable in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- server - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- server - Variable in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- server - Variable in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- server - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.PeriodicMemStoreFlusher
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.RemoteProcedureResultReporter
-
- server - Variable in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- server - Variable in class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- server - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- server - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- server - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- server - Variable in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- server - Variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- Server - Interface in org.apache.hadoop.hbase
-
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
- SERVER_ARG - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKMainServer
-
- SERVER_COLUMN_PATTERN - Static variable in class org.apache.hadoop.hbase.AsyncMetaTableAccessor
-
A regex for parsing server columns from meta.
- SERVER_COLUMN_PATTERN - Static variable in class org.apache.hadoop.hbase.MetaTableAccessor
-
A regex for parsing server columns from meta.
- SERVER_CRASH_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SERVER_KEYTAB_KERBEROS_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication.JaasConfiguration
-
- SERVER_NAME - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
-
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SERVER_NAME_KEY - Static variable in class org.apache.hadoop.hbase.trace.HBaseSemanticAttributes
-
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_QUEUE_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- SERVER_TO_COMPONENT - Static variable in class org.apache.hadoop.hbase.http.HttpRequestLog
-
- SERVER_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
-
- serverAdded(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- serverAdded(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server has joined the cluster.
- serverAdded(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- serverAdded(ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- ServerAndLoad - Class in org.apache.hadoop.hbase.master.balancer
-
Data structure that holds servername and 'load'.
- ServerAndLoad(ServerName, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- serverBuckets - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- ServerCall<T extends ServerRpcConnection> - Class in org.apache.hadoop.hbase.ipc
-
Datastructure that holds all necessary to a method invocation and then afterward, carries the
result.
- ServerCall(int, BlockingService, Descriptors.MethodDescriptor, RPCProtos.RequestHeader, Message, CellScanner, T, long, InetAddress, long, int, ByteBuffAllocator, CellBlockBuilder, RpcServer.CallCleanup) - Constructor for class org.apache.hadoop.hbase.ipc.ServerCall
-
- serverChanged() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- serverChannel - Variable in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- serverChannel - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- serverChannelClass - Variable in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- serverChannelClass() - Method in class org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
-
- serverClass - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- serverClass - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- serverClass - Variable in enum org.apache.hadoop.hbase.thrift.ImplType
-
- ServerCommandLine - Class in org.apache.hadoop.hbase.util
-
Base class for command lines that start up various HBase daemons.
- ServerCommandLine() - Constructor for class org.apache.hadoop.hbase.util.ServerCommandLine
-
- ServerConfigurationKeys - Interface in org.apache.hadoop.hbase.http
-
This interface contains constants for configuration keys used in the hbase http server code.
- ServerConnectionUtils - Class in org.apache.hadoop.hbase.client
-
- ServerConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ServerConnectionUtils
-
- ServerConnectionUtils.ShortCircuitingClusterConnection - Class in org.apache.hadoop.hbase.client
-
A ClusterConnection that will short-circuit RPC making direct invocations against the localhost
if the invocation target is 'this' server; save on network and protobuf invocations.
- ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper - Class in org.apache.hadoop.hbase.client
-
When we directly invoke
RSRpcServices.get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest)
on the same RegionServer through
ServerConnectionUtils.ShortCircuitingClusterConnection
in region CPs such as
RegionObserver.postScannerOpen(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment>, org.apache.hadoop.hbase.client.Scan, org.apache.hadoop.hbase.regionserver.RegionScanner)
to get other rows, the
RegionScanner
created
for the directly
RSRpcServices.get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest)
may not be closed until the outmost rpc call is
completed if there is an outmost
RpcCall
, and even worse , the
ServerCall.rpcCallback
may be override which would cause serious problem,so for
ServerConnectionUtils.ShortCircuitingClusterConnection.getClient(org.apache.hadoop.hbase.ServerName)
, if return
ServerConnectionUtils.ShortCircuitingClusterConnection.localHostClient
,we would add a wrapper class to wrap
it , which using
RpcServer.unsetCurrentCall()
and {RpcServer#setCurrentCall} to
surround the scan and get method call,so the
RegionScanner
created for the directly
RSRpcServices.get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest)
could be closed immediately,see HBASE-26812 for more.
- ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper.Operation<REQUEST,RESPONSE> - Interface in org.apache.hadoop.hbase.client
-
- serverCrashed(MasterProcedureEnv, RegionStateNode, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- serverCrashed(MasterProcedureEnv, RegionStateNode, ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- ServerCrashException - Exception in org.apache.hadoop.hbase.master.procedure
-
- ServerCrashException(long, ServerName) - Constructor for exception org.apache.hadoop.hbase.master.procedure.ServerCrashException
-
- serverCrashMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- ServerCrashProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
Handle crashed server.
- ServerCrashProcedure(MasterProcedureEnv, ServerName, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Call this constructor queuing up a Procedure.
- ServerCrashProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Used when deserializing from a procedure store; we'll construct one of these then call
#deserializeStateData(InputStream).
- serverCrashProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsMaster
-
- ServerErrors() - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker.ServerErrors
-
- ServerErrorTracker(long, int) - Constructor for class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
Constructor
- serverEventsListenerThread - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- ServerEventsListenerThread() - Constructor for class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- serverHasTooFewRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
Returns true iff a given server has less regions than the balanced amount
- serverIndexToHostIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- serverIndexToRackIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- serverIndexToRegionsOffset - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- serverIndicesSortedByLocality - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- serverIndicesSortedByRegionCount - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- ServerListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of server registration events.
- ServerLiveState() - Constructor for enum org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
-
- ServerLoad - Class in org.apache.hadoop.hbase
-
- ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
DONT USE this construction.
- ServerLoad(ServerName, ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- ServerLoad(ServerMetrics) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- serverLoadList - Variable in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- ServerLocalityCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
- ServerLocalityCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.ServerLocalityCostFunction
-
- serverLocks - Variable in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
-
- serverManager - Variable in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
- serverManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- ServerManager - Class in org.apache.hadoop.hbase.master
-
The ServerManager class manages info about region servers.
- ServerManager(MasterServices, RegionServerList) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
-
Constructor.
- ServerManager.ServerLiveState - Enum in org.apache.hadoop.hbase.master
-
- serverMap - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- ServerMetrics - Interface in org.apache.hadoop.hbase
-
This class is used for exporting current state of load on a RegionServer.
- ServerMetricsBuilder - Class in org.apache.hadoop.hbase
-
- ServerMetricsBuilder(ServerName) - Constructor for class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- ServerMetricsBuilder.ServerMetricsImpl - Class in org.apache.hadoop.hbase
-
- ServerMetricsImpl(ServerName, int, String, long, long, Size, Size, int, List<ReplicationLoadSource>, ReplicationLoadSink, Map<byte[], RegionMetrics>, Set<String>, long, long, Map<byte[], UserMetrics>, List<ServerTask>) - Constructor for class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- serverName - Variable in class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
-
- serverName - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- serverName(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- serverName - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- serverName(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- serverName - Variable in class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
-
- serverName - Variable in class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
-
- serverName - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- servername - Variable in class org.apache.hadoop.hbase.executor.ExecutorService
-
- serverName - Variable in class org.apache.hadoop.hbase.HRegionLocation
-
- serverName - Variable in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- serverName - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- serverName - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer.RegionDetails
-
- serverName - Variable in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ExecuteProceduresRemoteCall
-
- serverName - Variable in exception org.apache.hadoop.hbase.master.procedure.ServerCrashException
-
- serverName - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
Name of the crashed server to process.
- serverName - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- serverName - Variable in class org.apache.hadoop.hbase.master.RegionState
-
- serverName - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- serverName - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionInfo
-
- serverName - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The server name the Master sees us as.
- serverName - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- serverName - Variable in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- serverName - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- serverName - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- ServerName - Class in org.apache.hadoop.hbase
-
Name of a particular incarnation of an HBase Server.
- ServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- ServerName(Address, long) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- ServerName(String, long) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- serverName - Variable in class org.apache.hadoop.hbase.ServerName
-
- serverName - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- serverName - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- serverName - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- serverName - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor.Compact
-
- serverName - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.OnlineEntry
-
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
-
- SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SERVERNAME_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The serverName column qualifier.
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and startcode.
- serverNameHash - Variable in class org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
-
- 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
-
- ServerNonceManager.OperationContext - Class in org.apache.hadoop.hbase.regionserver
-
- ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
-
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
-
- ServerOperation(RemoteProcedureDispatcher.RemoteProcedure, long, Class<?>, byte[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.ServerOperation
-
- ServerOperationType() - Constructor for enum org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface.ServerOperationType
-
- serverOptions - Variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- serverOverloaded - Variable in exception org.apache.hadoop.hbase.HBaseServerException
-
- serverOverloaded - Variable in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- serverPrincipal - Variable in class org.apache.hadoop.hbase.security.SecurityInfo
-
- serverPrincipal - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
-
- ServerProcedureInterface - Interface in org.apache.hadoop.hbase.master.procedure
-
Procedures that handle servers -- e.g.
- ServerProcedureInterface.ServerOperationType - Enum in org.apache.hadoop.hbase.master.procedure
-
- ServerQueue - Class in org.apache.hadoop.hbase.master.procedure
-
- ServerQueue(ServerName, int, LockStatus) - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerQueue
-
- serverReadQueryMeter - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- ServerRegionReplicaUtil - Class in org.apache.hadoop.hbase.util
-
- ServerRegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- ServerRemoteProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- ServerRemoteProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- serverRemoved(ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- serverRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server was removed from the cluster.
- serverRemoved(ServerName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl.ServerEventsListenerThread
-
- ServerRequest() - Constructor for class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
-
- serverRequest() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
- ServerRequestCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- serverRequestSizes - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestHeapSizeChecker
-
- serverRows - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.RequestRowsChecker
-
- ServerRpcConnection - Class in org.apache.hadoop.hbase.ipc
-
Reads calls from a connection and queues them for handling.
- ServerRpcConnection(RpcServer) - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- ServerRpcConnection.ByteBuffByteInput - Class in org.apache.hadoop.hbase.ipc
-
- ServerRpcController - Class in org.apache.hadoop.hbase.ipc
-
Used for server-side protobuf RPC service invocations.
- ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- serverRunQueue - Variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
-
- servers - Variable in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- servers - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- servers - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- servers - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- serversByLoad - Variable in class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- ServerSideScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
-
Provides server side metrics related to scan operations.
- ServerSideScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
- serversIncluded - Variable in class org.apache.hadoop.hbase.client.SimpleRequestController.TaskCountChecker
-
- serversName - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
-
- serversName - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- serverSource - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- serversPerHost - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- serversPerRack - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- SERVERSTART_WAIT_MAX_KEY - Static variable in class org.apache.hadoop.hbase.util.RegionMover
-
- ServerState - Enum in org.apache.hadoop.hbase.master.assignment
-
Server State.
- ServerState() - Constructor for enum org.apache.hadoop.hbase.master.assignment.ServerState
-
- ServerStateNode - Class in org.apache.hadoop.hbase.master.assignment
-
State of Server; list of hosted regions, etc.
- ServerStateNode(ServerName) - Constructor for class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
Track the statistics for a single region
- ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
- ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
-
Tracks the statistics for multiple regions
- ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- serverStats - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
-
- serversThatCannotSpecifyBindIP() - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- serversToIndex - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- ServerTask - Interface in org.apache.hadoop.hbase
-
Information about active monitored server tasks
- ServerTask.State - Enum in org.apache.hadoop.hbase
-
Task state
- ServerTaskBuilder - Class in org.apache.hadoop.hbase
-
Builder for information about active monitored server tasks
- ServerTaskBuilder() - Constructor for class org.apache.hadoop.hbase.ServerTaskBuilder
-
- ServerTaskBuilder.ServerTaskImpl - Class in org.apache.hadoop.hbase
-
- ServerTaskImpl(String, String, ServerTask.State, long, long) - Constructor for class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- serverToAverageLatencyMap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- serverToBufferedCounterMap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- serverToFailedCounterMap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- serverToFlushWorkerMap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
The map between each region server to its flush worker
- serverToMaxLatencyMap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
Deprecated.
- ServerTooBusyException - Exception in org.apache.hadoop.hbase.ipc
-
Throw this in RPC call if there are too many pending requests for one region server
- ServerTooBusyException(Address, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
-
- ServerTooBusyException(InetSocketAddress, long) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
-
Deprecated.
- serverTrackerTimeout - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- ServerType - Enum in org.apache.hadoop.hbase.client
-
Select server type i.e destination for RPC request associated with ring buffer.
- ServerType() - Constructor for enum org.apache.hadoop.hbase.client.ServerType
-
- ServerType(String) - Constructor for enum org.apache.hadoop.hbase.util.DNS.ServerType
-
- serverVersion - Variable in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- serverWithProvider - Variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- serverWrapper - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- serverWriteQueryMeter - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- service - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.MasterCoprocessorService
-
Deprecated.
- service - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionCoprocessorService
-
Deprecated.
- service - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorServiceBackwardCompatiblity.RegionServerCoprocessorService
-
Deprecated.
- service - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- service - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- service - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- service(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.RESTServletContainer
-
This container is used only if authentication and impersonation is enabled.
- SERVICE_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- ServiceCaller<S,R> - Interface in org.apache.hadoop.hbase.client
-
Delegate to a protobuf rpc call.
- serviceException - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
The exception thrown within
Service.callMethod(com.google.protobuf.Descriptors.MethodDescriptor, RpcController, com.google.protobuf.Message, RpcCallback)
if any.
- serviceInterface - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- serviceName - Variable in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- ServiceNotRunningException - Exception in org.apache.hadoop.hbase
-
- ServiceNotRunningException() - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
-
- ServiceNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
-
- ServiceNotRunningException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
-
- ServiceNotRunningException(Throwable) - Constructor for exception org.apache.hadoop.hbase.ServiceNotRunningException
-
- services - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- services - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- services - Variable in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- services - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- services - Variable in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- services - Variable in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- services - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- services - Variable in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
- services - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- services - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- services - Variable in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- serviceStarted - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- serviceUGI - Variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-
- serviceUGI - Variable in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- Servlet() - Constructor for class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- servlet - Variable in class org.apache.hadoop.hbase.rest.ResourceBase
-
- ServletFilterHttpInteraction(HttpServletRequest, HttpServletResponse, FilterChain) - Constructor for class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.ServletFilterHttpInteraction
-
Creates a new ServletFilterHttpInteraction.
- SESSION_TIMEOUT_ZK - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- sessionExpiredFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- sessionTimeout - Variable in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
-
- sessionTimeout - Variable in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- sessionTimeoutMs - Variable in class org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
-
- set(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- set(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- set(String, String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- set(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- set(Cell) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Use passed bytes as backing array for this instance.
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Use passed bytes as backing array for this instance.
- set(KeyValue.KeyOnlyKeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer.ZKData
-
- set(long, TimeUnit) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Set the RateLimiter max available resources and refill period.
- set(List<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.DefaultStoreFileTracker
-
- set(List<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.FileBasedStoreFileTracker
-
- set(List<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- set(List<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
-
Set the store files.
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(long) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
Set the bit at the specified index to 1.
- set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Use passed bytes as backing array for this instance.
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes
-
Use passed bytes as backing array for this instance.
- set(long) - Method in class org.apache.hadoop.hbase.util.Counter
-
Deprecated.
- set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- set(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- SET_STATUS_SLEEP_TIME - Static variable in class org.apache.hadoop.hbase.chaos.ChaosConstants
-
- setAbortFailure(String, String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setAbortRequested() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Sets the abort state if not already set.
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Append
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Get
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Get
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the ACL for this operation.
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the ACL for this operation.
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Put
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the ACL for the operation.
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the ACL for the operation.
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setACL(AccessControlList) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setAcl(String, List<ACL>, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setAcl is an idempotent operation.
- setActions(Permission.Action[]) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- setAfterSplit(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Set the age of the last applied operation
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- setAgeOfLastShippedOp(long, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the age of the last edit that was shipped
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setAgeOfLastShippedOpByTable(long, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the age of the last edit that was shipped group by table
- setAllowCoreThreadTimeout(boolean) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
Allows timing out of core threads.
- setAllowed(boolean) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setAllowNullValueProperties(boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting whether the caller wants to see the partial results when server returns
less-than-expected cells.
- setAlreadyClosed() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setAppDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setArchiveTables(List<String>) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Set the tables to be archived.
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- setAsyncPrefetch(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
Deprecated.
- setAsyncPrefetch(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setAttempt(int) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
- setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Sets an attribute.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set a value in the webapp context.
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- setAttributes(Attributes) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Get
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the authorizations to be used by this Query n
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- setAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Deprecated.
- setAuths(Connection, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Sets given labels globally authorized for the user.
- 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.
- setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setBackerMasterNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setBackgroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setBackoffPolicy(RetryCounter.BackoffPolicy) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setBalancerDecisions(List<RecentLogs.BalancerDecision>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- setBalancerDecisionsRequest(MasterProtos.BalancerDecisionsRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- setBalancerOn(Boolean) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Set the balancer on/off.
- setBalancerRan(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set true if the balancer ran, otherwise false.
- setBalancerRejections(List<RecentLogs.BalancerRejection>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- setBalancerRejectionsRequest(MasterProtos.BalancerRejectionsRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- setBalancerRunning(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setBandwidth(double) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
- setBandwidth(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setBandwidth(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setBandwidth(long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the speed, in bytes per second, for any one RegionServer to replicate data to the peer.
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of cells to return for each call to next().
- setBatch(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setBatchLimit(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setBatchProgress(int) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setBatchProgress(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setBindAddress(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setBlink(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setBlockCache(BlockCache) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Only used for unit test which doesn't start region server.
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the blockCacheEnabled flag
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the block cache enabled flag.
- setBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBlocksize(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBlocksize(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set block size to use when writing
- setBlocksize(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setBlocksLocalWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setBlocksLocalWithSsdWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setBlocksTotalWeight(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setBloomFilterFaulty(BlockType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setBloomFilterSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the bloom filter type.
- setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setBold(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setBooleanIfUnset(String, boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setBulkLoaded(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setBulkToken(String) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Called from replication sink, where it manages bulkToken(staging directory) by itself.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
Set whether blocks should be cached for this Get.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether blocks should be cached for this Scan.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the setCacheBloomsOnWrite flag.
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the cache bloom filters on write flag.
- setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the setCacheDataOnWrite flag
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the cache data on write flag.
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the setCacheIndexesOnWrite flag
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the cache indexes on write flag.
- setCacheMissCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCacheMobBlocks(Scan, boolean) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
-
Sets the attribute of caching blocks in the scan.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Set the number of rows that will be fetched on next
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setCallable(CancellableRegionServerCallable) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setCallBack(RpcCallback) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Sets a callback which has to be executed at the end of this RPC call.
- setCallBack(RpcCallback) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- setCallDetails(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setCallMethodCount(String, Map<String, Long>) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- setCallMethodSize(String, Map<String, Long>) - Method in class org.apache.hadoop.hbase.ipc.CallQueueInfo
-
- setCallQueueLen(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Set the call queue length.
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- setCallTimeMs(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setCallTimeout(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
- setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setCancelled(Call) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Switch for the background CatalogJanitor thread.
- setCells(ArrayList<Cell>) - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
This is not thread safe.
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setCellScanner(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setCellSet(CellSet, CellSet) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
Setting the CellSet of the segment - used only for flat immutable segment for setting immutable
CellSet after its creation in immutable segment constructor
- setCellSet(CellSet, CellSet) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
Setting the CellSet of the segment - used only for flat immutable segment for setting immutable
CellSet after its creation in immutable segment constructor
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Append
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Sets the visibility expression associated with cells in this Mutation.
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Put
-
- setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Set the chance that a row is included.
- setChar(char) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
-
- setCharset(String) - Method in interface org.apache.hadoop.hbase.filter.RegexStringComparator.Engine
-
Set the charset used when matching
- setCharset(String) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JavaRegexEngine
-
- setCharset(String) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Specifies the
Charset
to use to convert the row key to a String.
- setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setCheckingEndTimestamp(Instant) - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- setCheckingStartTimestamp(Instant) - Method in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- setCheckMetaOnly() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Set hbase:meta check mode.
- setChildrenLatch(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor on procedure-load to restore the latch state
- setChoreService(ChoreService) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setClass(String, Class<?>, Class<?>) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setClassLoader(ClassLoader) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setCleanerChoreRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setCleanerChoreRunning(RpcController, MasterProtos.SetCleanerChoreRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setCleanReplicationBarrier(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setCleanReplicationBarrierTable(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setClientAckTime(long) - Method in class org.apache.hadoop.hbase.procedure2.CompletedProcedureRetainer
-
- setClientAddress(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setClientAddress(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Call this when the next invocation of call should close the scanner
- setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- setClosedRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- setClosedRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setClosing(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Exposed for some very specific unit tests.
- setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as down by deleting the znode.
- setClusterId(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setClusterId(ClusterId) - Method in class org.apache.hadoop.hbase.master.CachedClusterId
-
Succeeds only once, when setting to a non-null value.
- 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
- setClusterId(ZKWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setClusterIds(List<String>) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- setClusterKey(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setClusterKey(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setClusterKey(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Set the clusterKey which is the concatenation of the slave cluster's:
hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
- setClusterLoad(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
Pass RegionStates and allow balancer to set the current cluster load.
- setClusterMetrics(ClusterMetrics) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as up.
- setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setColumnFamilies(Collection<ColumnFamilyDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Adds a column family.
- setColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Query
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp) on a
per CF bases.
- setColumnFamilyTimeRange(byte[], long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setColumns(List<byte[]>) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setColumns(List<ColumnSchemaModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setCommonDirectoryPermission() - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- setCompactedCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompactingCellCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Compression types supported in hbase.
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Compression types supported in hbase.
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table compaction enable flag.
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setting the table compaction enable flag.
- setCompactionsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- setCompactionState(CompactionState) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setComparatorClass(Class<? extends CellComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompletedSequenceId(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setCompleteSequenceId(ClusterStatusProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setCompletionTime(long) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- setCompositeSnapshot(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Compression types supported in hbase.
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Compression types supported in hbase.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set whether the tags should be compressed along with DataBlockEncoding.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set whether the tags should be compressed along with DataBlockEncoding.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setComputedSteps(long) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setComputedTotalCost(double) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setConcurrentCallsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.Lz4Codec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.LzoCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.ZstdCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Codec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCodec
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- 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.DefaultHeapMemoryTuner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- setConf(Configuration, ZKWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- setConf(Configuration, ZKWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.UserProvider
-
- 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.tool.CanaryTool
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- setConfigParallel(FileSystem, List<Path>, BiConsumer<FileSystem, Path>, Configuration) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- 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.
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Setter for storing a configuration setting.
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setter for storing a configuration setting in map.
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
-
- setConflictWaitIterationMs(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- setConnection(NettyServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcFrameDecoder
-
- setConnection(NettyServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServerRequestDecoder
-
- 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.
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
-
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the consistency level for this operation
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setContainerOperations(RowMutations) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setContainerOperations(Row) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setContainerOperations(Collection<? extends Row>) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setContainerOperations(HBaseSemanticAttributes.Operation...) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setContentLength(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setContents(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteArrayBackedNode
-
- setContents(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteBufferBackedNode
-
- setContents(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.ByteBufferBackedNode
-
- setContents(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap.Node
-
- setContext(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Set the metrics context tag
- setContextAttributes(ServletContextHandler, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
-
Stores an exception encountered during RPC invocation so it can be passed back through to the
client.
- setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Add a table coprocessor to this table.
- setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Add a table coprocessor to this table.
- setCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessor(CoprocessorDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setCoprocessors(Collection<CoprocessorDescriptor>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setCoprocessorToMap(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Add coprocessor to values Map
- setCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setCorePoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setCostFuncInfoList(List<String>) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
-
- setCouldNotCommunicateWithServer(MutableBoolean) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setCount(int) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ColumnCount
-
Set the current count to a new count
- setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
-
nn
- setCryptoAESOption() - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
-
- setCurBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurBlockCacheSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current blockcache size used gauge
- setCurBlockCacheSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current blockcache size used gauge
- setCurBlockCacheSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- setCurBlockCacheUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurMemStoreSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
Set the current global memstore size used gauge
- setCurMemStoreSizeGauge(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
-
Set the current global memstore size used gauge
- setCurMemStoreSizeGauge(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
-
- setCurMemStoreUsed(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurrentBuffer(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.BufferedEncodedSeeker
-
- setCurrentBuffer(ByteBuff) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set on which buffer there will be done seeking.
- setCurrentBuffer(ByteBuff) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
-
- setCurrentCall(RpcCall) - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setCurrentCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setCurrentPath(Path) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- setCurrentPath(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- setCurrentState(String, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- setCurrentState(T, SpaceQuotaSnapshot) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
- setCurrentState(TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
-
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
-
- setCursorPosition(int, int) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- setCursorPosition(int, int) - Method in interface org.apache.hadoop.hbase.hbtop.terminal.Terminal
-
- setCurTaskZKVersion(MutableInt) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setDaemonThreadRunning(T) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(T, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(T, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setData is NOT an idempotent operation.
- setData(ZKWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZKWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZKWatcher, ZKUtil.ZKUtilOp.SetData) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns a setData ZKUtilOp
- setData(String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
Returns a setData ZKUtilOp
- SetData(String, byte[]) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- SetData(String, byte[], int) - Constructor for class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- setDataBlockEncoder(HFileDataBlockEncoder) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- setDataBlockEncoder(HFileDataBlockEncoder, Configuration) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
- setDataBlockEncoder(HFileDataBlockEncoder, Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- setDataBlockEncoder(HFileDataBlockEncoder) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- setDataBlockEncoderInTest(HFileDataBlockEncoder) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Should be used only in tests.
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set data block encoding algorithm used in block cache.
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set data block encoding algorithm used in block cache.
- setDataBlockIndexReader(HFileBlockIndex.CellBasedKeyBlockIndexReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- setDataBlockIndexReader(HFileBlockIndex.CellBasedKeyBlockIndexReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- setDataForClientZkUntilSuccess(String, byte[]) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
Set data for client ZK and retry until succeed.
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setDataLocality(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setDataLocalityForSsd(float) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setDataSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- setDataSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- setDeadNodes(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setDeadServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setDefaultScanConfig(Scan) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- setDelegate(InputStream, long) - Method in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
- setDelegate(InputStream) - Method in class org.apache.hadoop.hbase.io.DelegatingInputStream
-
- setDeleted(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
This method is used when restarting where we need to rebuild the ProcedureStoreTracker.
- setDeletedIfDeletedByThem(ProcedureStoreTracker) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
For the global tracker, we will use this method to build the holdingCleanupTracker, as the
modified flags will be cleared after rolling so we only need to test the deleted flags.
- setDeletedIfModified(long...) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Set the given bit for the procId to delete if it was modified before.
- setDeletedIfModifiedInBoth(ProcedureStoreTracker) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- setDeletedIfPartial(ProcedureStoreTracker, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
Deprecated.
- setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setDeleteIf(ProcedureStoreTracker, BiFunction<BitSetNode, Long, Boolean>) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- setDeprecatedProperties() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setDescription(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setDescription(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- setDescription(String, String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Sets the region/store name, for logging.
- setDescription(String) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- setDeserializerReference(CacheableDeserializer<Cacheable>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- setDestination(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Set the destination server for the plan for this region.
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
Provide the configuration from the SplitLogManager
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the replication factor to hfile(s) belonging to this family
- setDFSReplication(short) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setDFSReplication(short) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the replication factor to hfile(s) belonging to this family
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- setDictionary(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- setDidTry(boolean) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setDisableBalancerChoreForTest(boolean) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
- setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Display the full report from fsck.
- setDistributed(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.DumpOptions
-
- setDone(String, SplitLogManager.TerminationStatus) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setDone(CellScanner) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
IMPORTANT: always call this method if the call finished without any exception to tell
the HBaseRpcController
that we are done.
- setDone(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setDouble(String, double) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setDropBehind(Boolean) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- setDryRun(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
-
Updates BalancerRequest to run the balancer in dryRun mode.
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Append
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the durability for this mutation n
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Put
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setEditsRead(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setEditsSinceRestart(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.thrift.HBaseServiceHandler
-
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Set the current thread local effective user
- setEmptyRegionInfoRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of regions with empty region info.
- setEmptyRegionInfoRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
n
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
-
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- setEnabledState(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- setEnablingState(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- setEncoding(String) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator.JoniRegexEngine
-
- setEncodingState(EncodingState) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- setEncodingState(EncodingState) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Sets the encoding state.
- setEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the raw crypto key attribute for the family
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the raw crypto key attribute for the family
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the encryption algorithm for use with this family
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the encryption algorithm for use with this family n
- setEncryptor(Encryptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- setEncryptor(Encryptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
-
- setEncryptor(Encryptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setEndOfFile(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setEntries(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setEntry(SingleResponse.Entry) - Method in class org.apache.hadoop.hbase.client.SingleResponse
-
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setEnum(String, T) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setErr(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- setError(int, Row, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Sets the error from a particular action.
- setError(Span, Throwable) - Static method in class org.apache.hadoop.hbase.trace.TraceUtil
-
- setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Set the handler for calling out of RPC for error conditions.
- setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
-
Set the EventLoopGroup and channel class for AsyncRpcClient
.
- setEventLoopConfig(Configuration, EventLoopGroup, Class<? extends Channel>) - Static method in class org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper
-
Set the EventLoopGroup and channel class for AsyncFSWALProvider
.
- setEventReady(ProcedureEvent<?>, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the setEvictBlocksOnClose flag.
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the evict bloom filters on close flag.
- setEvictCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.Call
-
Set the exception when there is an error.
- setException(Exception) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
-
- setExceptionResponse(Throwable, String, RPCProtos.ResponseHeader.Builder) - Static method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- setExceptionResults(int, IOException, VisibilityLabelsProtos.VisibilityLabelsResponse.Builder) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- setExcludeNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setExcludeNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setExcludeNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the collection of namespaces which should not be replicated when all user tables are
configured to be replicated.
- setExcludeTableCFsMap(Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setExcludeTableCFsMap(Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setExcludeTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the mapping of table name to column families which should not be replicated.
- setExecCommand(String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine.DuFileCommand
-
- setExecutorType(ExecutorType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
-
- setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- setExpirationDate(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- setFailed(Throwable) - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setFailed(IOException) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set failed with an exception to pass on.
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Sets an exception to be communicated back to the Service
client.
- setFailure(Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
- setFailure(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setFailure(RemoteProcedureException) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setFailureInfo(FailureInfo) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setFailureResultForNonce(NonceKey, String, User, IOException) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
If the failure failed before submitting it, we may want to give back the same error to the
requests with the same nonceKey.
- setFamilies(Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setFamily(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setFamily(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setFamily(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFields(int, ScannerContext.LimitScope, long, long, ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
Set all fields together.
- setFields(int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
Set all fields together.
- setFileCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
-
Apply the specified server-side filter when performing the Query.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setFilterByOperator(LogQueryFilter.FilterByOperator) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setFilteredReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFinalFunctionCosts(String) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setFindPort(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setFirst(T) - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
-
- setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the first element of the pair.
- setFirst(A) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- setFirstRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setFirstRow(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
-
Deprecated.
Fix inconsistencies found by fsck.
- setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixHFileLinks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixReplication(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Set replication fix mode.
- setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setFloat(String, float) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setFlusherAndCompactor(MasterRegionFlusherAndCompactor) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
-
- setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This sets the class associated with the flush policy which determines determines the stores
need to be flushed when flushing a region.
- setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This sets the class associated with the flush policy which determines determines the stores
need to be flushed when flushing a region.
- setFlushSizeLowerBounds(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- setForceExclusive() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Set exclusive mode.
- setForegroundColor(Color) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setFoundFirstRange() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
Set or clear the indication if the first KV has been found.
- setFromTimedQuota(RateLimiter, QuotaProtos.TimedQuota) - Static method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- setFsCreatedListener(Consumer<HRegion>) - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- setFsDefault(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- setGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Set a gauge to a specific value.
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Set a single gauge to a value.
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setGlobalMemStoreLimit(long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Sets the global memstore limit to a new size.
- setGlobalMemStoreLimit(long) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
Sets the global memstore limit to a new size.
- setGlobalMemStoreLimits(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- setGroups(Groups) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
- setGuaranteedClientSideOnly(MutableBoolean) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setHashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- setHashLoc(int, int) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
-
- setHasWait() - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- setHBaseVersion(String) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setHdfs(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.DumpOptions
-
- setHdfsEntry(HbckRegionInfo.HdfsEntry) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- setHead(LRUDictionary.BidirectionalLRUMap.Node) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary.BidirectionalLRUMap
-
- setHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setHeapSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- setHeapSize(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.ProgressFields
-
- setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setHeartbeatMessage(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setHoles(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of holes.
- setHoles(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the HBase table.
- setHTableSpecificConf() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setHttpClient(HttpClient) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Append
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Get
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setId(String) - Method in class org.apache.hadoop.hbase.client.Put
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setId(long) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setIfUnset(String, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setIgnoreDeleteForTesting(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
Temporary function that is used by unit tests only
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setIgnoreRegionsInTransition(boolean) - Method in class org.apache.hadoop.hbase.client.BalanceRequest.Builder
-
Updates BalancerRequest to run the balancer even if there are regions in transition.
- setIncludesMemStoreTS(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
- setIncludesMemStoreTS(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- setIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setInconsistentRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of inconsistent regions.
- setInconsistentRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setIndexType(CompactingMemStore.IndexType) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- setInfoServerPort(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setInitialAndLastState() - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- setInitialFunctionCosts(String) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setInitialized(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- setInitTotalCost(double) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the inMemory flag
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the in memory flag.
- setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setInMemoryCompaction(MemoryCompactionPolicy) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the in memory compaction policy.
- setInMemoryCompactionCompleted() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- setInMemoryCompactionFlag() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- setInMemoryFlushed() - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopCompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.aircompressor.HadoopDecompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliCompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.brotli.BrotliDecompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Compressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.lz4.Lz4Decompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaCompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.xz.LzmaDecompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdCompressor
-
- setInput(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.zstd.ZstdDecompressor
-
- setInput(Configuration, Map<String, Collection<Scan>>, Path) - Static method in class org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
-
- setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(JobConf, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(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(Job, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, String, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setInstance(FileArchiverNotifierFactory) - Static method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
-
- setInt(String, int) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setIntHeader(String, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setIsMajor(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Specify if this compaction should be a major compaction based on the state of the store
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Get
-
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the isolation level for this query.
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setIssueDate(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the initialization vector n
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the initialization vector n
- setJarPath(String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setJitter(float) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setJVMVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setKeepAliveTime(long, TimeUnit) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- setKeepAliveTimeMillis(long) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
-
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the keep deleted cells policy.
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- setKeepDeletedCells(KeepDeletedCells) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- setKeepDeletes(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setKerberosNameRulesKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setKey(ByteBuffer, int, int) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to create
new OffheapKeyOnlyKeyValue.
- setKey(ByteBuffer, int, int, short) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to create
new OffheapKeyOnlyKeyValue.
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the secret key n
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the secret key n
- setKey(byte[], long) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- setKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever there is a need to
create new KeyOnlyKeyValue.
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- setKeyId(int) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- setKeytabConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setKeyValues(Configuration, String, Collection<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.util.ConfigurationUtil
-
- 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.
- setLastAppliedOpAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- setLastAppliedOpAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- setLastCachedAt(long) - Method in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
For tests only, sets lastCachedAt so we can force a refresh
- setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLastHost(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- setLastMajorCompactionTimestamp(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setLastPeekedCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setLastPushedSequenceId(MasterProcedureEnv, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- setLastPushedSequenceIdForTable(MasterProcedureEnv, TableName, Map<String, Long>) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- setLastReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- setLastRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setLastRow(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
-
- setLastSeqId(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- setLastSequenceIds(String, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- setLastSequenceIds(String, Map<String, Long>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Set the max sequence id of a bunch of regions for a given peer.
- setLastSequenceIds(String, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- setLastShippedAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- setLastShippedAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSource
-
- setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- setLastTouched(long) - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
- setLastUpdate(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to initialize the Procedure internals after the creation/deserialization.
- setLastWalPath(Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- setLastWalPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
-
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLeftoverRegions(Iterator<Region>) - Method in class org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
-
Sets a new collection of Regions as leftovers.
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the length of this range.
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setLimit(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the limit of rows for this scan.
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- setLimit(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Limits the byte range upto a specified value.
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- setLimiter(Map<K, QuotaLimiter>, K, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- setLiveNodes(List<StorageClusterStatusModel.Node>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setLiveServerMetrics(Map<ServerName, ServerMetrics>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setLoad(List<ServerAndLoad>, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- setLoadBalancer(LoadBalancer) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the value indicating whether loading CFs on demand should be allowed (cluster default is
false).
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- setLocation(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setLocations(Path, Path...) - Method in class org.apache.hadoop.hbase.io.FileLink
-
NOTE: This method must be used only in the constructor! It creates a List with the specified
locations for the link.
- setLogDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setLoggingUncaughtExceptionHandler(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sets an UncaughtExceptionHandler for the thread which logs the Exception stack if the thread
dies.
- setLogLevel(String, String) - Static method in class org.apache.hadoop.hbase.logging.InternalLog4jUtils
-
- setLogLevel(String, String) - Static method in class org.apache.hadoop.hbase.logging.Log4jUtils
-
- setLong(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setMajorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setMajorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMajorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setMajorRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
Sets compaction "major range".
- setMajorRangeFull() - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.SplitStripeCompactionRequest
-
Set major range of the compaction to the entire compaction 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.
- setMasterAddress(ZKWatcher, String, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Set master address into the master
znode or into the backup subdirectory of backup
masters; switch off the passed in znode
path.
- setMasterCoprocessorNames(List<String>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMasterInfoPort(int) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMasterInMaintenanceMode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
This method maintains an ephemeral znode.
- setMasterName(ServerName) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the master service.
- setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
-
Set the master service.
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- setMasterTasks(List<ServerTask>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- setMax(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max attempt times for an admin operation.
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max attempt times for an operation.
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setMaxAttempts(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max attempt times for an operation.
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMaxCompactedStoreFileRefCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Sets the maximum size upto which a region can grow to after which a region split is
triggered.
- setMaxFileSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMaxFileSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Sets the maximum size upto which a region can grow to after which a region split is triggered.
- setMaxFileSize(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setMaxHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setMaxKeyValueSize(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the maximum key-value size specified by the provided
AsyncConnection
's
Configuration
instance, via the configuration key
hbase.client.keyvalue.maxsize
.
- setMaxKeyValueSize(int) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setMaxPoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxPoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxProcId(long) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureLoader
-
Called by ProcedureStore.load() to notify about the maximum proc-id in the store.
- setMaxQueueSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxQueueSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum result size.
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set the maximum number of values to return per row per Column Family
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return per row per Column Family
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the max retry times for an admin operation.
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the max retry times for an operation.
- setMaxRetries(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the max retry times for an operation.
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setMaxSize(long) - Method in interface org.apache.hadoop.hbase.io.hfile.ResizableBlockCache
-
Sets the max heap size that can be used by the BlockCache.
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- setMaxSleepTime(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setMaxThroughput(double) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- setMaxValues(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the maximum number of versions to retain.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set maximum versions to keep
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- setMaxVersions(int) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Represents the maximum size of the memstore after which the contents of the memstore are
flushed to the filesystem.
- setMemStoreFlushSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMemStoreFlushSize(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Represents the maximum size of the memstore after which the contents of the memstore are
flushed to the filesystem.
- setMemStoreFlushSize(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setMemStoreSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setMemStoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setMerged(boolean) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- setMergeEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table region merge enable flag.
- setMergeEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setMergeEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setting the table region merge enable flag.
- setMetaAssigned(RegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- setMetaBlockIndexReader(HFileBlockIndex.ByteArrayKeyBlockIndexReader) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- setMetaBlockIndexReader(HFileBlockIndex.ByteArrayKeyBlockIndexReader) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
- setMetaEntry(HbckRegionInfo.MetaEntry) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setMetaLocation(ZKWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of hbase:meta
in ZooKeeper to the specified server address.
- setMetaLocation(ZKWatcher, ServerName, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of hbase:meta
in ZooKeeper to the specified server address.
- setMetaReplicaCount(int) - Method in class org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer
-
- setMethodDescriptor(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
- setMethodName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setMetricsSource(JvmPauseMonitorSource) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
-
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- setMin(long) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- 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
- setMinIndexNumEntries(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMinMaxModifiedProcIds(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
Will be called when restarting where we need to rebuild the ProcedureStoreTracker.
- setMinorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setMinorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMinorCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setMinThreshold(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
Overwrite min threshold for compaction
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set minimum versions to retain.
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the minimum number of versions to keep.
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- setMinVersions(int) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the mob compact partition policy for the family.
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobCompactPartitionPolicy(MobCompactPartitionPolicy) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the mob compact partition policy for the family.
- setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Enables the mob for the family.
- setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Enables the mob for the family.
- setMobFileCache(MobFileCache) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Only used for unit test which doesn't start region server.
- setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Sets the mob threshold of the family.
- setMobThreshold(long) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setMobThreshold(long) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Sets the mob threshold of the family.
- setMoreResultsForScan(ScannerCallable.MoreResults) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setMoreResultsInRegion(ScannerCallable.MoreResults) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setMovesCalculated(int) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set how many moves were calculated by the balancer.
- setMovesExecuted(int) - Method in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
-
Set how many of the calculated moves were actually executed by the balancer.
- setMultiGetsCount(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setMultiMutationsCount(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setMultiplier(float) - Method in class org.apache.hadoop.hbase.master.balancer.CostFunction
-
- setMultiServiceCalls(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setMvcc(long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- setMvccReadPoint(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setMvccReadPoint(Scan, long) - Static method in class org.apache.hadoop.hbase.client.PackagePrivateFieldAccessor
-
- setMvccReadPoint(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the mvcc read point used to open a scanner.
- setName(String) - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
-
- setName(String) - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
-
- setName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
-
- setNamedQueueEvent(int) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- setNamedQueueEvent(int) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- setNamedQueueRecorder(NamedQueueRecorder) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setNamedQueueRecorder(NamedQueueRecorder) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Set Online SlowLog Provider
- setNamespace(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the namespace filter regex
- setNamespaceQuota(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
Set quota for the namespace
- setNamespaceQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceQuota(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceQuotaSnapshot(String, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Stores the given snapshot
for the given namespace
in this chore.
- setNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setNamespaces(Set<String>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setNamespaces(Set<String>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets a unique collection of HBase namespaces that should be replicated to this peer.
- setNamespaces(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesModel
-
- setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setNeedCursorResult(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
When the server is slow or we scan a table with many deleted data or we use a sparse filter,
the server will response heartbeat to prevent timeout.
- setNeedResults(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setNewRegions(RegionInfo[]) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
Will be called in moveToNextRegion when currentRegion is null.
- setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ClientSimpleScanner
-
- setNewStartKey() - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setNewVersionBehavior(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- setNextRegionForUnload(int) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
-
- setNextState(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Set the next state for the procedure.
- setNextState(int) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Set the next state for the procedure.
- setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
-
- setNonce(NonceGenerator, Row, Action) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- setNonceKey(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to set the value to the newly created procedure.
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
-
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table normalization enable flag.
- setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizationEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setting the table normalization enable flag.
- setNormalizerOn(boolean) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
Set region normalizer on/off
- setNormalizerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
-
Set region normalizer on/off
- setNormalizerRunning(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setNormalizerRunning(RpcController, MasterProtos.SetNormalizerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setNormalizerTargetRegionCount(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the target region count of table normalization .
- setNormalizerTargetRegionCount(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizerTargetRegionCount(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setNormalizerTargetRegionSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the target region size of table normalization.
- setNormalizerTargetRegionSize(long) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setNormalizerTargetRegionSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setNoStripeMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- setNumActionsPerServer(int) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the number of threads in the pool for running maps.
- setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of map tasks for the given job configuration to the number of regions the given
table has.
- setNumMovedRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- setNumNamespacesInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of namespaces in violation of a space quota.
- setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the number of regions the
given table has.
- setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the number of regions the
given table has.
- setNumRegions(int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- setNumRegions(int) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- setNumRegionsAdded(int) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
-
- setNumRegionSizeReports(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of region size reports the master currently has in memory.
- setNumServers(int) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- setNumSpaceQuotas(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of space quotas defined.
- setNumTableInSpaceQuotaViolation(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
Sets the number of table in violation of a space quota.
- setOffheapMemStore(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
Deprecated.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
The parent of a region split is offline while split daughters hold references to the parent.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
Deprecated.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHRegionInfo
-
Deprecated.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
The parent of a region split is offline while split daughters hold references to the parent.
- setOffPeak(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- setOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the beginning of this range.
- setOldestEditTimeToNow() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- setOldestWalAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- setOldestWalAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- setOldestWalAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- setOldestWalAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setOneRowLimit() - Method in class org.apache.hadoop.hbase.client.Scan
-
Call this when you only want to get one row.
- setOpenRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- setOpenRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- setOpenSeqNum(long) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- setOperation(Scan) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setOperation(Row) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setOperation(Collection<? extends Row>) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setOperation(HBaseSemanticAttributes.Operation) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the status code for the operation(Mutation) at the specified position.
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for a whole admin operation.
- setOperationTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for the background flush operation.
- setOperationTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setOperationTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setOperationTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Set operation timeout for this mutator instance
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
-
- setOperationTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for a whole operation such as get, put or delete.
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- setoPsShipped(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setOrClearAuths(Connection, String[], String, boolean) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
- setOrigLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
Used to set original sequenceId for WALKeyImpl during WAL replay
- setOrphanRegionsOnFs(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of orphan regions on FS.
- setOrphanRegionsOnFs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setOrphanRegionsOnRs(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of orphan regions on RS.
- setOrphanRegionsOnRs(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setOSVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setOutputOnlyRowKey() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Option to print the row key only in case you just need the row keys from the WAL
- setOverlaps(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of overlaps.
- setOverlaps(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setOwner(MasterProcedureEnv, TransitRegionStateProcedure) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- setOwner(String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setOwnerParallel(FileSystem, String, String, Configuration, List<Path>) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setParam(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setParentProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to assign the parent to the newly created procedure.
- setPartialFlag(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker
-
Deprecated.
- setPathSpec(String[]) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setPattern(String, Pattern) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setPayloadMethod - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler.BuilderPayloadSetter
-
- setPeerConfig(ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- setPeerID(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setPeerState(String, boolean) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
-
- setPeerState(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerImpl
-
- setPeerState(String, boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
-
Set the state of peer, true
to ENABLED
, otherwise to DISABLED
.
- setPeerState(String, boolean) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
-
- setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- setPermissionParallel(FileSystem, short, List<Path>, Configuration) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- setPolicy(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- setPool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setPort(int) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryStream
-
- setPosition(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Update the position
index.
- setPosition(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the position to start seeking the WAL file n * initial position to start seeking the given
WAL file
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the setPrefetchBlocksOnOpen flag
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set or clear the prefetch on open flag.
- setPrefetchListener(Consumer<Boolean>) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
-
- setPrintStreams(PrintStream, PrintStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Append
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Get
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- setPriority(byte[]) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Put
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- setPriority(int) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set the priority for this operation.
- setPriority(TableName) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRpcController
-
Set the priority for this operation.
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
Sets the priority for the request
- setProcedure(TransitRegionStateProcedure) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- setProcessed(boolean) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- setProcessingTime(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setProcId(long) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- setProcId(long) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- setProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to assign the ID to the newly created procedure.
- setProcIds(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- setProgramDriver(ProgramDriver) - Static method in class org.apache.hadoop.hbase.mapred.Driver
-
- setProgress(int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setProgress(int, long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setProgress(int, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setProperties(Map<String, String>) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setProperty(String, String) - Method in class org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
-
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setQualifier(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setQualifier(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setQualifier(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- setQueueId(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setQueueTime(int) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setQuietMode(boolean) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setQuota(MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setQuota(MasterProtos.SetQuotaRequest, MasterQuotaManager.SetQuotaOperations) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Setup the global quota information.
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- setQuotas(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified table.
- setQuotas(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified namespace.
- setQuotaSnapshot(SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- setQuotasObserver(Configuration) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- setRackManager(RackManager) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setRandomGeneratorForTest(Random) - Static method in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Sets a random generator to be used for look-ups instead of computing hashes.
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadahead(Long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- setReaderRunning(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- setReadLatency(long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- setReadListener(ReadListener) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table as read only sets all the columns in the table as read only.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setting the table as read only sets all the columns in the table as read only.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
Set flags that make this region read-only.
- setReadRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setReadRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadRpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setReadRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
-
- setReadRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each read(get, scan) rpc request.
- setReadRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.WriteState
-
- setReadSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setReadType(Scan.ReadType) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the read type for this scan.
- setReadType(HBaseSemanticAttributes.ReadType) - Method in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
- setReason(String) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
-
- setReason(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setRecovered(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
-
Used when deserializing.
- setRegionBoundariesCheck() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Set region boundaries check mode.
- setRegionCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Sets the region coprocessor env.
- setRegionFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered n * when not null, serves as a filter; only
log entries from this region will be printed
- setRegionId(long) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setRegionInfo(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- setRegionLocation(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Enable or Disable the memstore replication from the primary region to the replicas.
- setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setRegionMemstoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setRegionMemStoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Enable or Disable the memstore replication from the primary region to the replicas.
- setRegionMetrics(List<RegionMetrics>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRegionName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setRegionName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setRegionPlans(List<String>) - Method in class org.apache.hadoop.hbase.client.BalancerDecision.Builder
-
- setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Sets the number of replicas per region.
- setRegionReplication(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setRegionReplication(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Sets the number of replicas per region.
- setRegionRequest(byte[], AsyncBatchRpcRetryingCaller.RegionRequest) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
-
- setRegions(List<StorageClusterStatusModel.Node.Region>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRegions(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRegions(List<TableRegionModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
-
- setRegionServerFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the region server filter regex
- setRegionServerGroup(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Set the RSGroup for this table, specified RSGroup must exist before create or modify table.
- setRegionServerQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setRegionServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Set the list of region servers for that peer
- setRegionServerServices(RegionServerServices) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- setRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- setRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- setRegionsInTransition(List<RegionState>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
This sets the class associated with the region split policy which determines when a region
split should occur.
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
This sets the class associated with the region split policy which determines when a region
split should occur.
- setRegionStateInMeta(Map<String, RegionState.State>) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- setRegionStateInMeta(Map<String, RegionState.State>) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Update region state in Meta only.
- setRegionStateInMeta(RpcController, MasterProtos.SetRegionStateInMetaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Update state of the region in meta only.
- setRegionStateToMerging(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
-
Set the region states to MERGING state
- setRegionUsage(Map<RegionInfo, Long>) - Method in class org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
-
- setRegionUsage(Map<RegionInfo, Long>) - Method in interface org.apache.hadoop.hbase.quotas.QuotaSnapshotStore
-
Updates this
with the latest snapshot of filesystem use by region.
- setRegionUsage(Map<RegionInfo, Long>) - Method in class org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
-
- setRemoteAddress(Address) - Method in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
-
- setRemoveParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setRenew(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Indicate whether we make a call only to renew the lease, but without affected the scanner in
any other way.
- setRenew(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Get
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Query
-
Specify region replica id where Query will fetch data from.
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setReplicateAllUserTables(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setReplicateAllUserTables(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setReplicateAllUserTables(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Configures HBase to replicate all user tables (not system tables) to the peer.
- setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setReplicationEndpointImpl(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets the ReplicationEndpoint plugin class for this peer.
- setReplicationLag(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setReplicationLoadSink(ReplicationLoadSink) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setReplicationLoadSources(List<ReplicationLoadSource>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setReplicationScope(int) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Sets replication scope all & only the columns already in the builder.
- setReplicationScope(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- setReporter(CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- setReportTimestamp(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequest(CompactionRequestImpl) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- setRequestCount(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequestCountPerSecond(long) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setRequests(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRequests(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRequestSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setResponse(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.Call
-
Set the return value when there is no error.
- setResponse(Message, CellScanner, Throwable, String) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Set the response resulting from this RPC call.
- setResponse(Message, CellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- setResponseHeader(HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.ProfileServlet
-
- setResponseSize(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setResponseSizeBytes(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setRestoredRegion(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setRESTVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setResult(Action, Object) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Sets the non-error result from a particular action.
- setResult(Result) - Method in class org.apache.hadoop.hbase.client.SingleResponse.Entry
-
- setResult(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner.HFileDeleteTask
-
- setResult(boolean) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner.CleanerContext
-
- setResult(byte[]) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The procedure may leave a "result" on completion.
- setResults(Object[]) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setRetryDespiteFastFailMode(boolean) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setRetryPause(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the base pause time for retrying.
- setRetryPause(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
- setRetryPauseForCQTBE(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
- setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
- setRetryPauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setRetryPauseForServerOverloaded(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
- setRetryPauseForServerOverloaded(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
n * True (default) if the append operation should return the results.
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setReverse(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a reversed one
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
-
alter the reversed scan flag
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- setRIT(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of regions in transition.
- setRIT(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRITCountOverThreshold(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the count of the number of regions that have been in transition over the threshold time.
- setRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRITOldestAge(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the oldest region in transition.
- setRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRollback() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
Called by the ProcedureExecutor to mark rollback execution
- setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setRootProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setRow(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setRow(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setRow(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setRowAccess(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRowAccess(RowAccess<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to set the
Filter
to be used.
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the row key by which output will be filtered n * when not null, serves as a filter; only
log entries from this row will be printed
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set offset for the row per Column Family.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set offset for the row per Column Family.
- setRowPrefixFilter(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey
starts with the specified prefix.
- setRowPrefixFilter(Scan, String) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- setRowPrefixFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the rowPrefix key prefix by which output will be filtered n * when not null, serves as a
filter; only log entries with rows having this prefix will be printed
- 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.
- setRpcControllerCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- 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.
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set timeout for each rpc request when doing background flush.
- setRpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Set rpc timeout for this mutator instance
- setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
-
- setRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each rpc request.
- setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- setRsGroupInfoManager(RSGroupInfoManager) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- setRsRpcServices(RSRpcServices) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setRsRpcServices(RSRpcServices) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setRunner(Runnable) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- setRunning(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreBase
-
Change the state to 'isRunning', returns true if the store state was changed, false if the
store was already in that state.
- setRunning(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setRunningProcedureCount(int) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- setRunningProcedureCount(int) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Set the number of procedure running.
- setRunningProcedureCount(int) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- setRunningProcedureCount(int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- 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.
- setScanFilter(Scan, List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- setScanInfo(ScanInfo) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Set scan info, used by test
- setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScannerState(ScannerContext.NextState) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setScannerState(ScannerContext.NextState) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
Note that this is not a typical setter.
- setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the list of
Scan
objects.
- setScanTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
As now we have heartbeat support for scan, ideally a scan will never timeout unless the RS is
crash.
- setScanTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setScope(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setScope(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setSecond(int) - Method in class org.apache.hadoop.hbase.util.ObjectIntPair
-
- setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the second element of the pair.
- setSecond(B) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setSecurityEnabled(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered n * when nonnegative, serves as a filter; only
log entries with this sequence id will be printed
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- setSequenceId(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- setSequenceId(long) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given seqId.
- setSequenceId(long) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
Internal usage.
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- setSequenceId(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given seqId to the cell.
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- setSequenceNumber(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- setSerial(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setSerial(boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets whether we should preserve order when replicating, i.e, serial replication.
- setServer(ServerName) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setServerClass(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setServerImpl(CommandLine, Configuration) - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- setServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setServerOverloaded(boolean) - Method in exception org.apache.hadoop.hbase.HBaseServerException
-
Necessary for parsing RemoteException on client side
- setServerSideHConnectionRetriesConfig(Configuration, String, Logger) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Changes the configuration to set the number of retries needed when using Connection internally,
e.g.
- setServerState(ServerName, ServerState) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
-
- setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- setShouldRerun() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Check if we should rerun fsck again.
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- setSignatureSecretFileKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setSize(long) - Method in interface org.apache.hadoop.hbase.quotas.RegionSize
-
Updates the size of the Region.
- setSize(long) - Method in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
-
- setSize(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setSizeLimit(ScannerContext.LimitScope, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setSizeLimitScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setSizeLimitScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setSizeProgress(long, long) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setSizeProgress(long, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setSizeScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
Change the scope in which the size limit is enforced
- setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- setSkipChecksum(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
Specify that the
ChecksumType
should not be included in the attributes.
- setSkipResetSeqId(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- setSkipWait(boolean) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- setSleepInterval(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setSlowLogPayloads(List<TooSlowLog.SlowLogPayload>) - Method in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- setSlowLogResponseRequest(AdminProtos.SlowLogResponseRequest) - Method in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
Deprecated.
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setSnapshotCleanupEnabled(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.SnapshotCleanupTracker
-
Set snapshot auto clean on/off
- 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
-
- setSocketAddr(String, InetSocketAddress) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Sets the socket buffer size used for responding to RPCs.
- setSortField() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- setSortFieldAndFields(Field, List<Field>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- setSource(MetricsThriftServerSource) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- setSourceStartupStatus(boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- setSpan(Span) - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.ImmutableHRegionInfo
-
Deprecated.
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
Change the split status flag.
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHRegionInfo
-
Deprecated.
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Set or clear the split status flag.
- setSplitEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
Setting the table region split enable flag.
- setSplitEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setSplitEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setting the table region split enable flag.
- setSplitOrMergeEnabled(boolean, boolean, MasterSwitchType...) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- setSplitOrMergeEnabled(RpcController, MasterProtos.SetSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setSplitOrMergeEnabled(boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- setSplitOrMergeOn(boolean, boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- setSplitRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- setSplitRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- setStackIndexes(List<Integer>) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to initialize the Procedure internals after the creation/deserialization.
- setStackTrace(Throwable) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
-
- setStartAndStopRows(Scan, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncAdminBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setStartLogErrorsCnt(int) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set the number of retries that are allowed before we start to log.
- setStartLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartRowForReplicaCallable(ScannerCallable) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
Set the start row for the replica callable based on the state of the last result received.
- setStartStopRowForPrefixScan(byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setStartStopRowForPrefixScan(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set a filter (using stopRow and startRow) so the result set only contains rows where the rowKey
starts with the specified prefix.
- setStartTime(long) - Method in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setStartTime(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCall
-
Set the time when the call starts to be executed.
- setStartTime(long) - Method in class org.apache.hadoop.hbase.ipc.ServerCall
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- setStat(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- setState(RegionState.State, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
- setState(ServerState) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- setState(MonitoredTask.State) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- setState(ProcedureProtos.ProcedureState) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setState(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- setState(ServerTask.State) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- setStatistics(RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
-
Set load information about the region to the information about the result
- setStatus(MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- setStatus(String) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- setStatus(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- setStatus(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setStatus(String) - Method in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- setStatus(MonitoredTask) - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
- setStatusMsg(String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- setStatusOfTaskZNode(String, String) - Method in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
sets given Status for Task Znode
- setStatusOfTaskZNodeCallback - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
Callback used while setting status of a given task, Logs given status.
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the storage policy for use with this family
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setStoragePolicy(Path, String) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Set the source path (directory/file) to the specified storage policy.
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the storage policy for use with this family
- setStoragePolicy(String, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Set the directory of CF to the specified storage policy.
- setStoragePolicy(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Set storage policy for a whole region.
- setStoragePolicy(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Sets storage policy for given path.
- setStoragePolicy(FileSystem, Path, String, boolean) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- setStoragePolicyFromFileName(List<Path>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- setStoreCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreFileIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStorefileIndexSizeKB(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStoreFileRootLevelIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStoreFileUncompressedDataIndexSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStoreRefCount(int) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStores(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStores(Set<String>) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- setStoreSequenceIds(Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setStreamOptions(FSDataInputStream) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- setStrings(String, String...) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setStub(AdminProtos.AdminService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- setStub(S) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- setStubByServiceName(ServerName) - Method in class org.apache.hadoop.hbase.client.CancellableRegionServerCallable
-
- setStubByServiceName(ServerName) - Method in class org.apache.hadoop.hbase.client.ClientServiceCallable
-
- setStubByServiceName(ServerName) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
Set the RCP client stub
- setSubmittedRows(AsyncProcessTask.SubmittedRows) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setSubmittedTime(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to initialize the Procedure internals after the creation/deserialization.
- setSummary() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Set summary mode.
- setSwitchEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker.SwitchStateTracker
-
Set the switch on/off
- setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer.FullyQualifiedRow
-
- setTableCFsMap(Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
-
- setTableCFsMap(Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- setTableCFsMap(Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
-
Sets an explicit map of tables and column families in those tables that should be replicated to
the given peer.
- setTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the table filter regex
- setTableFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Sets the tables filter.
- setTableInfo(HbckTableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableInfo(HbckTableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- setTableName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
-
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
-
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setTableQuota(TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setTableQuotaSnapshot(TableName, SpaceQuotaSnapshot) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
Stores the quota state for the given table.
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setTableRegionStatesCount(Map<TableName, RegionStatesCount>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setTableRep(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Set the table's replication switch if the table's replication switch is already not set.
- setTableReplication(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
Set the table's replication switch if the table's replication switch is already not set.
- setTables(List<TableModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- setTableState(TableName, TableState.State) - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
Set table state to provided.
- setTableStateInMeta(TableState) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
-
- setTableStateInMeta(TableState) - Method in interface org.apache.hadoop.hbase.client.Hbck
-
Update table state in Meta only.
- setTableStateInMeta(RpcController, MasterProtos.SetTableStateInMetaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Update state of the table in meta only.
- setTableStateToDisabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabled
- setTableStateToDisabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabling
- setTableStateToEnabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabled
- setTableStateToEnabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabling
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- setTags(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setTags(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setTags(List<Tag>) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setTags(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setTags(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setTags(List<Tag>) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setTags(List<Tag>) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setTagType(byte) - Method in interface org.apache.hadoop.hbase.TagBuilder
-
Set type of the tag.
- setTagType(byte) - Method in class org.apache.hadoop.hbase.TagBuilderImpl
-
- setTagValue(byte[]) - Method in interface org.apache.hadoop.hbase.TagBuilder
-
Set the value of the tag.
- setTagValue(byte[]) - Method in class org.apache.hadoop.hbase.TagBuilderImpl
-
- setTargets(List<NormalizationTarget>) - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan.Builder
-
- setTargetTableName(String[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- setTaskNode(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setTasks(List<ServerTask>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setTestingSleepTime(long) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- setThird(C) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setThreadName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockContext
-
- setThreads(int, int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set the min, max number of worker threads (simultaneous connections).
- setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setTime(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- setTimeDuration(String, long, TimeUnit) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
We are interested in only those tables that have not changed their state in hbase:meta during
the last few seconds specified by hbase.admin.fsck.timelag
- setTimeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setTimeLimitScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- setTimeLimitScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setTimeout(IOException) - Method in class org.apache.hadoop.hbase.ipc.Call
-
called from timeoutTask, prevent self cancel
- setTimeout(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setTimeout(long) - Method in class org.apache.hadoop.hbase.procedure2.util.DelayedUtil.DelayedContainerWithTimestamp
-
- setTimeout(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setTimeoutExecutorUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
At end of timeout, wake ourselves up so we run again.
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
Re run the procedure after every timeout to write new WAL entries so we don't hold back old
WALs.
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ReopenTableRegionsProcedure
-
At end of timeout, wake ourselves up so we run again.
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
-
- setTimeoutFailure(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- setTimeoutFailure(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor when the timeout set by setTimeout() is expired.
- setTimeoutForWriteLock(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setTimeProgress(long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext
-
- setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
-
- setTimer(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Append
-
Sets the TimeRange to be used on the Get for this append.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets the TimeRange to be used on the Get for this increment.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
- setTimeScope(ScannerContext.LimitScope) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
Change the scope in which the time limit is enforced
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.ByteBufferKeyValue
-
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- setTimestamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Append
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
Deprecated.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.client.Mutation.CellWrapper
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the timestamp of the delete.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Put
-
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given timestamp.
- setTimestamp(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCell
-
Sets with the given timestamp.
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter.KeyOnlyByteBufferExtendedCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyByteBufferExtendedCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.EmptyCell
-
- setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.PrivateCellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteByteBufferExtendedCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.PrivateCellUtil.TagRewriteCell
-
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
-
- setTimeStampNextToReplicate(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
TimeStamp of next edit targeted for replication.
- setTimestampOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setTimeStampOfNextToReplicate(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- setTimestampsOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- setTimestampStarted(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the time to live
- setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set the time to live
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setTimeToLive(String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the time to live of cell contents
- setTimeToLive(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set the time to live of cell contents
- setTimeToPurgeDeletes(long) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- setTimeToPurgeDeletes(long) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- setTimeUnit(TimeUnit) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setTitle(String) - Static method in class org.apache.hadoop.hbase.hbtop.terminal.impl.EscapeSequences
-
- setTitle(String) - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- setTo(long, long, long, int, int, long, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.IndexStatistics
-
- setToNewRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Set the row when there is change in row n
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalOpsProcessed(long) - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
-
- setTotalRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- setTotalRegions(int) - Method in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setTracker(CompactionLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- setTrackMetrics(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setTrailer(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- setTrailerIfPresent() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
To check whether a trailer is present in a WAL, it seeks to position (fileLength -
PB_WAL_COMPLETE_MAGIC.size() - Bytes.SIZEOF_INT).
- setTransitionState(MasterProcedureProtos.RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- setTries(int) - Method in class org.apache.hadoop.hbase.client.FastFailInterceptorContext
-
- setTS(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
-
- setTSAndType(long, byte) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Append
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the TTL desired for the result of the mutation, in milliseconds.
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Put
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
-
- setTTL(long) - Method in interface org.apache.hadoop.hbase.regionserver.ScanOptions
-
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setType(LogQueryFilter.Type) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setType(byte) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setType(Cell.Type) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setType(byte) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setType(Cell.Type) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- setUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setUncompressedStoreFileSize(Size) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setUnderline(boolean) - Method in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
-
- setUnknownServerNames(List<ServerName>) - Method in class org.apache.hadoop.hbase.ClusterMetricsBuilder
-
- setUnknownServerRegions(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of unknown server regions.
- setUnknownServerRegions(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setup(Mapper<ImmutableBytesWritable, Result, Text, LongWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, ImmutableBytesWritable>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellImporter
-
- setup(Mapper<ImmutableBytesWritable, Result, Import.CellWritableComparable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
-
- 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
-
Deprecated.
- setup(Mapper<ImmutableBytesWritable, Result, Import.KeyValueWritableComparable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueSortImporter
-
Deprecated.
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
-
- setup(Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- 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(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Cell>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALCellMapper
-
- setup(Mapper<WALKey, WALEdit, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALKeyValueMapper
-
Deprecated.
- setup(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- setup(Reducer<Text, ImmutableBytesWritable, Text, Text>.Context) - Method in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
-
- setup(Mapper<LongWritable, Text, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool.CompactionMapper
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- setup(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Setup controller for the given region server.
- setup(Mapper<BytesWritable, NullWritable, NullWritable, NullWritable>.Context) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- setupCellBlockCodecs(RPCProtos.ConnectionHeader) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
Set up cell block codecs n
- setupClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Setup our cluster connection if not already initialized.
- setupConf(Configuration, long, long, long) - Static method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- setupConnection() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- setupCryptoAESHandler(ChannelPipeline, CryptoAES) - Method in class org.apache.hadoop.hbase.security.NettyHBaseRpcConnectionHeaderHandler
-
Remove handlers for sasl encryption and add handlers for Crypto AES encryption
- setupCryptoCipher(RPCProtos.ConnectionHeader, RPCProtos.ConnectionHeaderResponse.Builder) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
Set up cipher for rpc encryption with Apache Commons Crypto n
- setupHTTPServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Setup an HTTP Server using Jetty to serve calls from THttpClient
- setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupLock() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- setupMasterlessConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Setup the connection class, so that it will not depend on master being online.
- setupNamespaceLock() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- setupNetty(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- setupNextScanner() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.Scanner
-
- setupParamters() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- setupReceiver(int) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- setupRegionLock() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- setupRegionReplicaReplication(MasterServices) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Create replication peer for replicating user-space Region Read Replicas.
- setupRIT(List<TransitRegionStateProcedure>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Create RegionStateNode based on the TRSP list, and attach the TRSP to the RegionStateNode.
- setupSaslConnection(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- setupSaslHandler(ChannelPipeline) - Method in class org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
-
- setupServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
Setting up the thrift TServer
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
-
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
Called by toSetQuotaRequestProto() the subclass should implement this method to set the
specific SetQuotaRequest properties.
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettingsFactory.QuotaGlobalsSettingsBypass
-
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- setupShortCircuitRead(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Do our short circuit read setup.
- setupTableLock() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupTestEnv() - Static method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setupTime(Configuration, String) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- setupWALAndReplication() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Setup WAL log and replication if enabled.
- setupWALEntrySinkFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- setupWindows(Configuration, ConfigurationManager) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
If running on Windows, do windows-specific setup.
- setUsedHeapSize(Size) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setUseExecutor(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
-
CompactedHFilesDischarger runs asynchronously by default using the hosting RegionServer's
Executor.
- setUser(User) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the user filter regex
- setUserGroups(String, String[]) - Method in class org.apache.hadoop.hbase.security.User.TestingGroups
-
- setUserMetrics(List<UserMetrics>) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setUserName(String) - Method in class org.apache.hadoop.hbase.client.LogQueryFilter
-
Deprecated.
- setUserName(String) - Method in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- setUsername(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- setUsernameConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setUserProviderForTesting(Configuration, Class<? extends UserProvider>) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
Set the
UserProvider
in the given configuration that should be instantiated
- setUserQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setUserQuota(String, TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setUserQuota(String, String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.CellBuilder
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(Bytes, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(Bytes, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.ExtendedCellBuilder
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setter for storing metadata as a (key, value) pair in map
- setValue(Bytes, Bytes) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Setter for storing metadata as a (key, value) pair in map
- setValue(byte[]) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setValue(byte[], int, int) - Method in interface org.apache.hadoop.hbase.RawCellBuilder
-
- setValue(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapEntry
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setValue(V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.COWEntry
-
- setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- setVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- setVersion(String) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, String, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersionNumber(int) - Method in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- setVersions(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Set minimum and maximum versions to keep.
- setVersions(int, int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Set minimum and maximum versions to keep
- setVersionsWithTimeToLive(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
Retain all versions for a given TTL(retentionInterval), and then only a specific number of
versions(versionAfterInterval) after that interval elapses.
- setVersionsWithTimeToLive(int, int) - Method in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- setVictimCache(BlockCache) - Method in interface org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
-
Specifies the secondary cache.
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the walEdit for the operation(Mutation) at the specified position.
- setWalGroupId(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setWALPosition(ServerName, String, String, long, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
-
- setWALPosition(ServerName, String, String, long, Map<String, Long>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
-
Set the current position for a specific WAL in a given queue for a given regionserver.
- setWALPosition(ServerName, String, String, long, Map<String, Long>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
-
- setWALReader(ReplicationSourceWALReader) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- setWALReaderEditsBufferBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
Sets the total usage of memory used by edits in memory read from WALs.
- setWALReaderEditsBufferBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- setWALReaderEditsBufferUsage(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Sets the amount of memory in bytes used in this RegionServer by edits pending replication.
- setWALRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
- setWALTrailer(WALProtos.WALTrailer) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
-
- setWarnTime(long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setWarnTime(long) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- setWatchIfNodeExists(ZKWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode, but only if exists.
- setWithPrefix(Configuration, String, Iterable<Map.Entry<String, String>>) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Sets all the entries in the provided Map<String, String>
as properties in the given
Configuration
.
- setWorkerState(ReplicationSourceShipper.WorkerState) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- setWriteBufferPeriodicFlush(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Set the periodical flush interval.
- setWriteBufferPeriodicFlush(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setWriteBufferPeriodicFlush(long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed checking once per second.
- setWriteBufferPeriodicFlush(long, long) - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Sets the maximum time before the buffer is automatically flushed.
- setWriteBufferPeriodicFlush(long, long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setWriteBufferPeriodicFlushTimeoutMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Set the max timeout before the buffer is automatically flushed.
- setWriteBufferPeriodicFlushTimerTickMs(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Set the TimerTick how often the buffer timeout if checked.
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
-
Override the write buffer size specified by the provided
AsyncConnection
's
Configuration
instance, via the configuration key
hbase.client.write.buffer
.
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
-
- setWriteEntry(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
-
- setWriteLatency(long) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- setWriteListener(WriteListener) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- setWriter(WALProvider.Writer) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- setWriterCreationTracker(Consumer<Path>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- setWriteRequestCount(long) - Method in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setWriteRpcTimeout(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.client.AsyncTableBuilder
-
Set timeout for each write(put, delete) rpc request.
- setWriteRpcTimeout(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- setWriteRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.Table
-
- setWriteRpcTimeout(int) - Method in interface org.apache.hadoop.hbase.client.TableBuilder
-
Set timeout for each write(put, delete) rpc request.
- setWriteRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.TableBuilderBase
-
- setWriteSuccess() - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTaskResult
-
- setZKCluster(MiniZooKeeperCluster) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- setZnodeAclsRecursive(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Set the znode perms recursively.
- SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- severity - Variable in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
-
- Severity() - Constructor for enum org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
-
- sf - Variable in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure.StoreFileSplitter
-
- sf - Variable in class org.apache.hadoop.hbase.mob.MobFile
-
- sfScanner - Variable in class org.apache.hadoop.hbase.mob.MobCell
-
- shade - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeProviderSelector
-
- SHADE_TOKEN_KIND_TEXT - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeProviderSelector
-
- ShadeClientTokenUtil - Class in org.apache.hadoop.hbase.security.provider.example
-
Used to acquire tokens for the ShadeSaslAuthenticationProvider.
- ShadeClientTokenUtil() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeClientTokenUtil
-
- ShadedAccessControlUtil - Class in org.apache.hadoop.hbase.security.access
-
Convert protobuf objects in AccessControl.proto under hbase-protocol-shaded to user-oriented
objects and vice versa.
- ShadedAccessControlUtil() - Constructor for class org.apache.hadoop.hbase.security.access.ShadedAccessControlUtil
-
- ShadeProviderSelector - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeProviderSelector() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeProviderSelector
-
- ShadeSaslAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeSaslAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeSaslAuthenticationProvider
-
- ShadeSaslClientAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeSaslClientAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeSaslClientAuthenticationProvider
-
- ShadeSaslClientAuthenticationProvider.ShadeSaslClientCallbackHandler - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeSaslClientCallbackHandler(Token<? extends TokenIdentifier>) - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeSaslClientAuthenticationProvider.ShadeSaslClientCallbackHandler
-
- ShadeSaslServerAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeSaslServerAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeSaslServerCallbackHandler(AtomicReference<UserGroupInformation>, Map<String, char[]>) - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler
-
- ShadeTokenIdentifier - Class in org.apache.hadoop.hbase.security.provider.example
-
- ShadeTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeTokenIdentifier
-
- ShadeTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.provider.example.ShadeTokenIdentifier
-
- shallowClone(HFileBlock, ByteBuff) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- SHARED_DATA_MAP - Static variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- sharedAsyncConnection - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- sharedAsyncConnectionLock - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- sharedConnection - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
This shared
Connection
is used for handling bulk load hfiles replication.
- SharedConnection - Class in org.apache.hadoop.hbase
-
Wraps a Connection to make it can't be closed or aborted.
- SharedConnection(Connection) - Constructor for class org.apache.hadoop.hbase.SharedConnection
-
- sharedConnectionLock - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- sharedData - Variable in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- sharedHFileCleanerPool - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- sharedLock - Variable in class org.apache.hadoop.hbase.procedure2.LockAndQueue
-
- sharedLock() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- sharedLockCount - Variable in class org.apache.hadoop.hbase.procedure2.LockedResource
-
- SharedMemHFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
- SharedMemHFileBlock(BlockType, int, int, long, ByteBuff, boolean, long, int, int, HFileContext, ByteBuffAllocator) - Constructor for class org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
-
- SharedMemoryMmapIOEngine - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
IO engine that stores data in pmem devices such as DCPMM.
- SharedMemoryMmapIOEngine(String, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.SharedMemoryMmapIOEngine
-
- sharedUnlock() - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- shareZK - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- SHELL_TIMESTAMP_FORMAT_EPOCH_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- shexec - Variable in class org.apache.hadoop.hbase.HealthChecker
-
- shift - Variable in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
-
- SHIFT_TIMESTAMP_LENGTH - Static variable in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- SHIFT_TIMESTAMP_LENGTH - Static variable in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- 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.
- shipBatch(long, int, long) - 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(WALEntryBatch) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
Do the shipping logic
- shipEditsTimeout - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- shipped() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.MobStoreScanner
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
Called after a batch of rows scanned (RPC) and set to be returned to client.
- shipped() - Method in interface org.apache.hadoop.hbase.regionserver.Shipper
-
Called after a batch of rows scanned and set to be returned to client.
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- shipped() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- shippedBatchesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- shippedBatchesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedBatchesKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedBytesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- shippedBytesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedBytesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- shippedBytesKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedBytesKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
-
- shippedCallback - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder
-
- shippedHFilesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- shippedHFilesCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedHFilesKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedKBsCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- shippedKBsCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedKBsKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedOpsCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- shippedOpsCounter - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shippedOpsKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- shipper - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerShippedCallBack
-
- Shipper - Interface in org.apache.hadoop.hbase.regionserver
-
This interface denotes a scanner as one which can ship cells.
- ShipperListener - Interface in org.apache.hadoop.hbase.regionserver
-
Implementors of this interface are the ones who needs to do some action when the
Shipper.shipped()
is called
- SHORT_HELP_OPTION - Static variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- SHORTCIRCUIT_BYTES_READ - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SHORTCIRCUIT_BYTES_READ_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- ShortCircuitingClusterConnection(Configuration, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface, ConnectionRegistry) - Constructor for class org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
-
- ShortCircuitMasterConnection - Class in org.apache.hadoop.hbase.client
-
A short-circuit connection that can bypass the RPC layer (serialization, deserialization,
networking, etc..) when talking to a local master
- ShortCircuitMasterConnection(MasterProtos.MasterService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- shortCompactions - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- shortName - Variable in class org.apache.hadoop.hbase.security.access.AccessChecker.InputUser
-
- shortName - Variable in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- shortOperationTimeout - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- SHOULD_REPLICATE_FLAG - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- 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
- shouldAssignFavoredNodes(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- shouldAssignRegionsWithFavoredNodes - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- shouldBeOnMaster(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContextImpl
-
- shouldCacheBlockOnRead(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Should we cache a block of a particular category? We always cache important blocks such as
index blocks, as long as the block cache is available.
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheCompactedBlocksOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks should be cached while writing during compaction, false if not
- shouldCacheCompressed(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheDataCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if data blocks should be compressed in the cache, false if not
- shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns whether the DATA blocks of this HFile should be cached on read or not (we always cache
the meta blocks, the INDEX and BLOOM blocks).
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCFBeCompacted(HRegionFileSystem, String, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- shouldCheckBulkLoads() - Method in class org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
-
- shouldCheckBulkLoads() - Method in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- shouldCheckBulkLoads() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
-
Returns whether thet caller should verify any bulk loads against this
.
- shouldCheckDescriptor - Variable in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- shouldCheckExecPermission - Variable in class org.apache.hadoop.hbase.security.access.AccessController
-
if we should check EXEC permissions
- shouldCheckHdfs() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldCopyHFileMetaKey(byte[]) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- shouldDispatchToScanQueue(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- shouldDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldDropBehind - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- shouldDropBehind - Variable in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- shouldDropBehind() - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- shouldDropBehind(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
-
- shouldDropBehindCompaction() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldDropCacheBehind - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
-
- shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldExclude(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Check if a path should not perform clear
- shouldFixAssignments() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixEmptyMetaCells() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixHdfsHoles() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixHdfsOrphans() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixHdfsOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixHFileLinks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixMeta() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixReferenceFiles() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixSplitParents() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixTableOrphans() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldFlush(long) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
-
- shouldFlush(HStore) - Method in class org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
-
- shouldFlush(HStore) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- shouldFlush(StringBuilder) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Should the memstore be flushed now
- shouldFlushStore(HStore) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Should the store be flushed because it is old enough.
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldIncludeMemStoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- shouldIncludeStore(HRegionFileSystem, String, Collection<StoreFileInfo>, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- shouldIncludeStore(HRegionFileSystem, String, Collection<StoreFileInfo>, long) - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
-
- shouldKillAfterStoreUpdate() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
-
- shouldKillAfterStoreUpdate(boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
-
- shouldKillBeforeStoreUpdate() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
-
- shouldKillBeforeStoreUpdate(boolean, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
-
- shouldLockOnCacheMiss(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
If we make sure the block could not be cached, we will not acquire the lock otherwise we will
acquire lock
- shouldLoginFromKeytab(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
In secure environment, if a user specified his keytab and principal, a hbase client will try to
login with them.
- shouldLoginFromKeytab() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
In secure environment, if a user specified his keytab and principal, a hbase client will try to
login with them.
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DateTieredCompactionPolicy
-
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
-
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- shouldPerformMajorCompaction(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- shouldPerformMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- shouldPerformMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Tests whether we should run a major compaction.
- shouldPrefetchOnOpen() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns true if blocks should be prefetched into the cache on open, false if not
- shouldPrintMeta - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- 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.
- shouldRemoveParents() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldReplaceExistingCacheBlock(BlockCache, BlockCacheKey, Cacheable) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Because of the region splitting, it's possible that the split key locate in the middle of a
block.
- shouldReplaceExistingCacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- shouldReplayRecoveredEdits(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether to replay the recovered edits to flush the results.
- shouldRerun() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- shouldRetryCreate(RemoteException) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- shouldRetryInspiteOfFastFail(FailureInfo) - Method in class org.apache.hadoop.hbase.client.PreemptiveFastFailInterceptor
-
Check to see if the client should try to connnect to the server, inspite of knowing that it is
in the fast fail mode.
- shouldRun - Variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- shouldScheduleConsumer() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- shouldSeek(TimeRange, long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
-
- shouldSeek(TimeRange, long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
-
- shouldSelectL0Files(StripeCompactionPolicy.StripeInformationProvider) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Returns true if the specified region should be split.
- shouldSplitRegion() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- shouldSplitWal - Variable in class org.apache.hadoop.hbase.master.procedure.RecoverMetaProcedure
-
Deprecated.
- shouldSplitWal - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- shouldStop - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- shouldStop(Cell) - Method in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- shouldStop(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedRegionScannerImpl
-
- shouldStop - Variable in class org.apache.hadoop.hbase.wal.OutputSink.WriterThread
-
- shouldSubmitSCP(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- shouldSyncWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Check whether we should sync the wal from the table's durability settings
- shouldUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Returns Whether we are presently using HBase checksum.
- shouldUseHeap(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
If expected block is data block, we'll allocate the ByteBuff of block from
ByteBuffAllocator
and it's usually an off-heap one,
otherwise it will allocate from heap.
- shouldUseScanner(Scan, HStore, long) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Allows to filter out scanners (both StoreFile and memstore) that we don't want to use based on
criteria such as Bloom filters and timestamp ranges.
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
This functionality should be resolved in the higher level which is MemStoreScanner, currently
returns true as default.
- shouldUseScanner(Scan, HStore, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
-
- shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- shouldWaitClientAck(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- shouldWaitClientAck(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
By default, the executor will keep the procedure result around util the eviction TTL is
expired.
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
-
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Whether there is an inline block ready to be written.
- shouldWriteBlock(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Determines whether there is a new block to be written out.
- showCommandDescription(TerminalPrinter, CommandDescription) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- showField(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- showField(int, Field, boolean, boolean, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
-
- showFieldScreen(String, List<Field>, EnumMap<Field, Boolean>, int, int, int, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
-
- showFiles - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- showFilters(List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
-
- showHeaders(List<Header>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- showHelpScreen(long, CommandDescription[]) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- showInput(String, String, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
-
- showMessage(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
-
- showMode(int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
-
- showMode(int, Mode, boolean, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- showModeScreen(Mode, List<Mode>, int, int, int) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- showProgress - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- showRecords(List<Header>, List<Record>, Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- showSchema - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- showScreenDescription(String) - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
-
- showScreenDescription(long) - Method in class org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
-
- showScreenDescription(Mode) - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
-
- showStats - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- showSummary(Summary) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- showTopScreen(Summary, List<Header>, List<Record>, Record) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- shuffle - Static variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Specify if we have to shuffle the map tasks.
- shutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
Shut down the service.
- shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the HBase cluster.
- shutdown() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the HBase cluster.
- shutdown() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- shutdown - Variable in class org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock.LockHeartbeatWorker
-
Returns Shuts down the thread clean and quietly.
- shutdown() - Method in class org.apache.hadoop.hbase.client.MetricsConnection
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Clean up the environment
- shutdown(E) - 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 class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
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.LruAdaptiveBlockCache.EvictionThread
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.EvictionThread
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- shutdown() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- shutdown() - Method in class org.apache.hadoop.hbase.ipc.RpcConnection
-
Just close connection.
- shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Shutdown the cluster.
- shutdown() - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- shutdown() - Method in class org.apache.hadoop.hbase.mob.MobFileCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- shutDown - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost.RegionEnvironment
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost.RegionServerEnvironment
-
- shutdown - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- shutdown - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost.WALEnvironment
-
- shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Shut down the client.
- shutdown() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
Shutdown any services that need to stop
- shutdown() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- shutdown(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Completely shutdown the ScheduleChore, which means we will call cleanup and you should not
schedule it again.
- shutdown() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Called when cache is no longer needed so that it can perform cleanup operations
- shutdown(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
nn
- shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- shutdown() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- shutdown() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
-
- shutdown() - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Stop accepting new writes.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Tell the underlying WAL providers to shut down, but do not clean up underlying storage.
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
persist outstanding WALs to storage and stop accepting new appends.
- shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- shutdown0() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcConnection
-
- shutdownBatchPool(ExecutorService) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- shutdownChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- shutdownGroupWhenClose - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcClient
-
- ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
-
Manage regionserver shutdown hooks.
- ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- ShutdownHook.DoNothingStoppable - Class in org.apache.hadoop.hbase.regionserver
-
- ShutdownHook.DoNothingThread - Class in org.apache.hadoop.hbase.regionserver
-
- ShutdownHook.ShutdownHookThread - Class in org.apache.hadoop.hbase.regionserver
-
- 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
-
- ShutdownHookManager.ShutdownHookManagerV1 - Class in org.apache.hadoop.hbase.util
-
- ShutdownHookManager.ShutdownHookManagerV2 - Class in org.apache.hadoop.hbase.util
-
- shutdownHookManagerClass - Static variable in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- ShutdownHookManagerV1() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV1
-
- ShutdownHookManagerV2() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV2
-
- ShutdownHookThread(Configuration, Stoppable, Thread, Runnable) - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook.ShutdownHookThread
-
- shutdownLongCompactions() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
Shutdown the long compaction thread pool.
- shutdownNow() - Method in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- shutdownPools() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- shutdownServer() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- shutdownWAL() - Method in class org.apache.hadoop.hbase.master.region.MasterRegion
-
- shutdownWAL(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- sidelineBigOverlaps - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- sidelineBigOverlaps(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo.HDFSIntegrityFixer
-
Sideline some regions in a big overlap group so that it will have fewer regions, and it is
easier to merge them later on.
- sidelineDir - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- sidelinedRegions - Variable in class org.apache.hadoop.hbase.util.HbckTableInfo
-
- sidelineFile(FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- sidelineRegionDir(FileSystem, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Sideline a region dir (instead of deleting it)
- sidelineRegionDir(FileSystem, String, HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
Sideline a region dir (instead of deleting it)
- signalAll() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- signalAll() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
In case the class is blocking on poll() waiting for items to be added, this method should awake
poll() and poll() should return.
- signaller - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler.PostOpenDeployTasksThread
-
Deprecated.
- signatureSecretFileKey - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- simpleAuth - Variable in class org.apache.hadoop.hbase.security.provider.BuiltInProviderSelector
-
- SimpleByteRange - Class in org.apache.hadoop.hbase.util
-
- SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
- SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
- SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- simpleClassName() - Method in enum org.apache.hadoop.hbase.thrift.ImplType
-
- 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
-
- SimpleLoadBalancer.BalanceInfo - Class in org.apache.hadoop.hbase.master.balancer
-
Stores additional per-server information about the regions added/removed during the run of the
balancing algorithm.
- simpleMergeOrFlatten(VersionedSegmentsList, String) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
-
- SimpleMovingAverage<T> - Class in org.apache.hadoop.hbase.util
-
SMA measure the overall average execution time of a specific method.
- SimpleMovingAverage(String) - Constructor for class org.apache.hadoop.hbase.util.SimpleMovingAverage
-
- SimpleMutableByteRange - Class in org.apache.hadoop.hbase.util
-
- SimpleMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
lacking a backing array and with an undefined viewport.
- SimpleMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over a new backing array of size capacity
.
- SimpleMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over the provided bytes
.
- simpleName - Variable in enum org.apache.hadoop.hbase.Size.Unit
-
- SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
-
- SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
lacking a backing array and with an undefined
viewport.
- SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over a new backing array of size capacity
.
- SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedMutableByteRange - Class in org.apache.hadoop.hbase.util
-
- SimplePositionedMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
lacking a backing array and with an undefined
viewport.
- SimplePositionedMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over a new backing array of size capacity
.
- SimplePositionedMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimpleProcedureScheduler - Class in org.apache.hadoop.hbase.procedure2
-
Simple scheduler for procedures
- SimpleProcedureScheduler() - Constructor for class org.apache.hadoop.hbase.procedure2.SimpleProcedureScheduler
-
- SimpleRegionNormalizer - Class in org.apache.hadoop.hbase.master.normalizer
-
Simple implementation of region normalizer.
- SimpleRegionNormalizer() - Constructor for class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- SimpleRegionNormalizer.NormalizeContext - Class in org.apache.hadoop.hbase.master.normalizer
-
- SimpleRegionNormalizer.NormalizerConfiguration - Class in org.apache.hadoop.hbase.master.normalizer
-
Holds the configuration values read from Configuration
.
- simpleReporter - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- SimpleReporter(MetricRegistry, PrintStream, Locale, TimeZone, TimeUnit, TimeUnit, MetricFilter) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter
-
- SimpleRequestController - Class in org.apache.hadoop.hbase.client
-
Holds back the requests if they reach any thresholds.
- SimpleRequestController(Configuration) - Constructor for class org.apache.hadoop.hbase.client.SimpleRequestController
-
- SimpleRequestController.RequestHeapSizeChecker - Class in org.apache.hadoop.hbase.client
-
limit the heap size for each request.
- SimpleRequestController.RequestRowsChecker - Class in org.apache.hadoop.hbase.client
-
limit the number of rows for each request.
- SimpleRequestController.RowChecker - Interface in org.apache.hadoop.hbase.client
-
Provide a way to control the flow of rows iteration.
- SimpleRequestController.SubmittedSizeChecker - Class in org.apache.hadoop.hbase.client
-
limit the heapsize of total submitted data.
- SimpleRequestController.TaskCountChecker - Class in org.apache.hadoop.hbase.client
-
limit the max number of tasks in an AsyncProcess.
- SimpleRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
The default scheduler.
- SimpleRpcScheduler(Configuration, int, int, int, int, PriorityFunction, Abortable, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
n * @param handlerCount the number of handler threads that will be used to process calls
- SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
- SimpleRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- SimpleRpcServer - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleRpcServer(Server, String, List<RpcServer.BlockingServiceAndInterface>, InetSocketAddress, Configuration, RpcScheduler, boolean) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Constructs a server listening on the named port and address.
- simpleRpcServer - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
- SimpleRpcServer.ConnectionManager - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleRpcServer.Listener - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
Listens on the socket.
- SimpleRpcServer.Listener.Reader - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleRpcServerResponder - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleRpcServerResponder(SimpleRpcServer) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder
-
Deprecated.
- SimpleSaslAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
Base client for client/server implementations for the "SIMPLE" HBase auth'n method.
- SimpleSaslAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.SimpleSaslAuthenticationProvider
-
- SimpleSaslClientAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
- SimpleSaslClientAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.SimpleSaslClientAuthenticationProvider
-
- SimpleSaslServerAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
-
- SimpleSaslServerAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.SimpleSaslServerAuthenticationProvider
-
- 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
-
- SimpleServerCall - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleServerCall(int, BlockingService, Descriptors.MethodDescriptor, RPCProtos.RequestHeader, Message, CellScanner, SimpleServerRpcConnection, long, InetAddress, long, int, ByteBuffAllocator, CellBlockBuilder, RpcServer.CallCleanup, SimpleRpcServerResponder) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleServerCall
-
Deprecated.
- SimpleServerRpcConnection - Class in org.apache.hadoop.hbase.ipc
-
Deprecated.
- SimpleServerRpcConnection(SimpleRpcServer, SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key
belongs to.
- SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- single() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
-
Create retry caller for single action, such as get, put, delete, etc.
- SINGLE_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Priority buckets config
- SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a single quote
- SingleByteBuff - Class in org.apache.hadoop.hbase.nio
-
An implementation of ByteBuff where a single BB backs the BBI.
- SingleByteBuff(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- SingleByteBuff(ByteBuffAllocator.Recycler, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- SingleByteBuff(RefCnt, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- singleCallDuration(long) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
Returns Calculate how long a single call took
- SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
-
A
Filter
that checks a single column value, but does not emit the tested column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Deprecated.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Deprecated.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for protobuf deserialization only.
- SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- SingleColumnValueFilter(byte[], byte[], CompareOperator, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Deprecated.
- SingleColumnValueFilter(byte[], byte[], CompareOperator, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- singleFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Single access bucket size
- singleFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Single access bucket size
- singleFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Single access bucket size
- singleLevelOnly - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Whether we require this block index to always be single-level.
- singleRackCase(RegionInfo, ServerName, String) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
-
- SingleRequestCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- SingleResponse - Class in org.apache.hadoop.hbase.client
-
Class for single action response
- SingleResponse() - Constructor for class org.apache.hadoop.hbase.client.SingleResponse
-
- SingleResponse.Entry - Class in org.apache.hadoop.hbase.client
-
- SingleServerRequestRunnable(MultiAction, int, ServerName, Set<CancellableRegionServerCallable>) - Constructor for class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.SingleServerRequestRunnable
-
- singleSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- singleSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- singleSourceSource - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- singleSourceSourceByTable - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
- SINGLETON - Static variable in class org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
-
- singleton - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- SINGLETON_ID - Static variable in class org.apache.hadoop.hbase.wal.WALFactory
-
- SingletonCoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- SingletonStorage() - Constructor for enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
-
- SingleWriteExampleCallable(Connection, TableName) - Constructor for class org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
-
- sink - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
-
- sink - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- sink - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
-
- sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionTask
-
- sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool
-
- sink - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.ZookeeperTask
-
- SINK_AGE_OF_LAST_APPLIED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_APPLIED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_APPLIED_HFILES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_APPLIED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_FAILED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- sinkFs - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- sinkMetrics - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- SinkPeer(ServerName, AdminProtos.AdminService.BlockingInterface) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- sinks - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
- sinkToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sinkToString
- sinkWriter - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
-
- size() - Method in class org.apache.hadoop.hbase.client.AsyncProcessTask.ListRowAccess
-
- size() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl.QueueRowAccess
-
- size() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
Count the mutations which haven't been processed.
- size() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Get the total number of Actions
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Returns Number of pairs in this container
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Number of KeyValues carried by this Mutation.
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the size of the underlying Cell []
- size() - Method in interface org.apache.hadoop.hbase.client.RowAccess
-
Returns the number of elements in this list.
- size() - Method in interface org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfigMap
-
- size() - Method in class org.apache.hadoop.hbase.CompoundConfiguration.ImmutableConfWrapper
-
- size() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- size() - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
-
- size() - Method in class org.apache.hadoop.hbase.favored.FavoredNodesPlan
-
- size() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- size() - Method in class org.apache.hadoop.hbase.filter.FilterListBase
-
- size() - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- size() - Method in class org.apache.hadoop.hbase.io.ByteArrayOutputStream
-
Returns The current size of the buffer.
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
-
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- size() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the total size of the block cache, in bytes.
- size - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- size - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- size - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- size - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Current size of cache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- size - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Current size of cache
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- size - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
-
- size - Variable in class org.apache.hadoop.hbase.ipc.BufferChain
-
- size() - Method in class org.apache.hadoop.hbase.ipc.BufferChain
-
- size() - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufferOutputStreamSupplier
-
- size() - Method in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufOutputStreamSupplier
-
- size() - Method in interface org.apache.hadoop.hbase.ipc.CellBlockBuilder.OutputStreamSupplier
-
- size - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- size() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection.ByteBuffByteInput
-
- size() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- size - Variable in class org.apache.hadoop.hbase.master.cleaner.DirScanPool
-
- size() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- size() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorkQueue
-
Returns the number of elements in this queue.
- size - Variable in class org.apache.hadoop.hbase.master.procedure.FairQueue
-
- size() - Method in class org.apache.hadoop.hbase.master.procedure.Queue
-
- size() - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- size() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- size() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Returns the number of elements in this queue.
- size - Variable in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- size() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- size - Variable in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.SnapshotWithSize
-
- size - Variable in class org.apache.hadoop.hbase.quotas.MasterQuotaManager.SizeSnapshotWithTimestamp
-
- size() - Method in class org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
-
- size - Variable in class org.apache.hadoop.hbase.quotas.RegionSizeImpl
-
- size() - Method in interface org.apache.hadoop.hbase.quotas.RegionSizeStore
-
Returns the number of entries in the store.
- size() - Method in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- size() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the size of the list even if some of the elements might be null.
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- size - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
-
Size of chunk in bytes
- size() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- size() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Returns The number of operations(Mutations) involved in this batch.
- size - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- size - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- Size - Class in org.apache.hadoop.hbase
-
It is used to represent the size with different units.
- Size(double, Size.Unit) - Constructor for class org.apache.hadoop.hbase.Size
-
- size - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats.FileInfo
-
- size() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
-
- size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
-
- size() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- size - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- size() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- size() - Method in class org.apache.hadoop.hbase.util.ObjectPool
-
Returns an estimated count of objects kept in the pool.
- size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- size() - Method in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- size() - Method in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- size() - Method in class org.apache.hadoop.hbase.util.SortedList
-
- size() - Method in class org.apache.hadoop.hbase.wal.WALEdit
-
- Size.Unit - Enum in org.apache.hadoop.hbase
-
- SIZE_IN_BYTES - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.Options
-
- SIZE_LIMIT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CloseChecker
-
- SIZE_PATTERN - Static variable in class org.apache.hadoop.hbase.util.PrettyPrinter
-
- SIZE_REGEX - Static variable in class org.apache.hadoop.hbase.util.PrettyPrinter
-
- SIZE_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SIZE_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SIZE_TO_SPLIT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The size the stripe should achieve to be considered for splitting into multiple stripes.
- SIZE_VALUE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- sizeAddedPreOperation() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- SizeAsBytesSerializer - Class in org.apache.hadoop.hbase.master.http.gson
-
Simplify representation of a
Size
instance by converting to bytes.
- SizeAsBytesSerializer() - Constructor for class org.apache.hadoop.hbase.master.http.gson.SizeAsBytesSerializer
-
- SizeAsBytesSerializer() - Constructor for class org.apache.hadoop.hbase.master.http.RegionVisualizer.SizeAsBytesSerializer
-
- SizeCachedByteBufferKeyValue - Class in org.apache.hadoop.hbase
-
This Cell is an implementation of
ByteBufferExtendedCell
where the data resides in off
heap/ on heap ByteBuffer
- SizeCachedByteBufferKeyValue(ByteBuffer, int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
- SizeCachedByteBufferKeyValue(ByteBuffer, int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
-
- SizeCachedKeyValue - Class in org.apache.hadoop.hbase
-
This class is an extension to KeyValue where rowLen and keyLen are cached.
- SizeCachedKeyValue(byte[], int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedKeyValue
-
- SizeCachedKeyValue(byte[], int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedKeyValue
-
- SizeCachedNoTagsByteBufferKeyValue - Class in org.apache.hadoop.hbase
-
This Cell is an implementation of
ByteBufferExtendedCell
where the data resides in off
heap/ on heap ByteBuffer
- SizeCachedNoTagsByteBufferKeyValue(ByteBuffer, int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
-
- SizeCachedNoTagsByteBufferKeyValue(ByteBuffer, int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
-
- SizeCachedNoTagsKeyValue - Class in org.apache.hadoop.hbase
-
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
- SizeCachedNoTagsKeyValue(byte[], int, int, long, int) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
-
- SizeCachedNoTagsKeyValue(byte[], int, int, long, int, short) - Constructor for class org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
-
- sizeData - Variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlockCountsPerFile
-
- SizedCellScanner - Interface in org.apache.hadoop.hbase.io
-
A CellScanner that knows its size in memory in bytes.
- sizeIndex - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- sizeIndex() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- sizeIndex - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- sizeIndex() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- sizeIndexOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- sizeMap - Variable in class org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
-
Maps each region to its size in bytes.
- SizeMultiWriter(CellComparator, int, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- sizeOf(byte[]) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Calculate the memory consumption (in byte) of a byte array, including the array header and the
whole backing byte array.
- SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of boolean in bytes
- SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of byte in bytes
- SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of char in bytes
- SIZEOF_CHUNK_HEADER - Static variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator
-
- SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of double in bytes
- SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of float in bytes
- SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of int in bytes
- SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of long in bytes
- SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of short in bytes
- sizeOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- sizeOfByteArray(int) - Method in class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
-
- sizeOfByteArray(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Calculate the memory consumption (in byte) of a part of a byte array, including the array
header and the part of the backing byte array.
- sizeOfByteArray(int) - Method in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
-
- sizeOfEntry - Static variable in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- sizeOfHFileRefsQueueGauge - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- sizeOfHFileRefsQueueGauge - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sizeOfHFileRefsQueueKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sizeOfLogQueue - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
-
- sizeOfLogQueue - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- sizeOfLogQueueGauge - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- sizeOfLogQueueGauge - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sizeOfLogQueueKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sizeOfStoreFilesIncludeBulkLoad(WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
Calculate the total size of all the store files
- sizePerFile - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
- sizeRollRequested - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- sizeScope - Variable in class org.apache.hadoop.hbase.regionserver.ScannerContext.LimitFields
-
- SizeSnapshotWithTimestamp(long, long) - Constructor for class org.apache.hadoop.hbase.quotas.MasterQuotaManager.SizeSnapshotWithTimestamp
-
- SizeStripeFlushRequest(CellComparator, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
-
- sizeToSplitAt - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- skip(long) - Method in class org.apache.hadoop.hbase.io.BoundedDelegatingInputStream
-
Call the delegate's skip(long)
method.
- skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Skips n
bytes of input from this input stream.
- skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
-
Skips n
bytes of input from this input stream.
- skip(long) - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
-
- skip(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Jumps the current position of this ByteBuff by specified length.
- skip(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Jumps the current position of this MBB by specified length.
- skip(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Skip src
's position forward over one encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
Bypass the next encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Skip src
's position forward over one encoded value.
- skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
Increment position in buffer.
- skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip buff
's position forward over one encoded value.
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- SKIP_EMPTY_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SKIP_LOAD_DUPLICATE_TABLE_COPROCESSOR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- SKIP_LOGIN_KEY - Static variable in class org.apache.hadoop.hbase.rest.RESTServer
-
- SKIP_RESET_SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.HStoreFile
-
Key for skipping resetting sequence id in metadata.
- skipBadLines - Variable in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Should skip bad lines
- skipBadLines - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Should skip bad lines
- skipBadLines - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Should skip bad lines
- skipCellsForMutation(ClientProtos.Action, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- skipCellsForMutations(List<ClientProtos.Action>, CellScanner) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- skipChecks - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo
-
- skipChecksum - Variable in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
-
- skipEmptyColumns - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Should skip empty columns
- skipErrors - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- skipFlush - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- skipForMerge(SimpleRegionNormalizer.NormalizerConfiguration, SimpleRegionNormalizer.NormalizeContext, RegionInfo) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Determine if a
RegionInfo
should be considered for a merge operation.
- skipForSplit(RegionState, RegionInfo) - Static method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Determine if a region in
RegionState
should be considered for a split operation.
- skipInitialSaslHandshake - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
-
- skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- skipLargeFiles(ArrayList<HStoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- skipNext() - Method in class org.apache.hadoop.hbase.procedure2.store.InMemoryProcedureIterator
-
- skipNext() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureIterator
-
Skip the next procedure
This method is used to skip the deserializing of the procedure to increase performance, as
when calling next we need to convert the protobuf message to the Procedure class.
- skippedCount - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- skippedEntries - Variable in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable
-
- skippedRegions - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- skipPersistence() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- skipRegionManagementAction(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Checks master state before initiating action over region topology.
- skipRegionManagementAction(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Checks master state before initiating action over region topology.
- skipReportingTransition(RegionServerServices.RegionStateTransitionContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Helper method for use in tests.
- skipResetSeqId - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- skipSignificand(PositionedByteRange, boolean) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip src
over the significand bytes.
- skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
If currently asleep, stops sleeping; if not asleep, will skip the next sleep cycle.
- skipSpaces(byte[], int) - Method in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- skipStoreFileRangeCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- skipTableStateCheck - Variable in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- skipVaruint64(PositionedByteRange, boolean) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip src
over the encoded varuint64.
- skipWait - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- sleep() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
Sleep for an expected amount of time.
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.MasterCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- sleep(long, int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Sleep and retry.
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas.RetryingRPC
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period.
- sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
-
- sleep(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
If interrupted, just prints out the interrupt on STDOUT, resets interrupt and returns
- SLEEP_DELTA_NS - Static variable in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- SLEEP_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- SLEEP_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
The target sleep time
- SLEEP_INTERVAL_MS_BETWEEN_RETRIES - Static variable in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
Sleep interval ms between ZK operation retries.
- SLEEP_INTERVAL_MS_MAX - Static variable in class org.apache.hadoop.hbase.MetaRegionLocationCache
-
- SLEEP_TIME - Static variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- SLEEP_TIMEOUT_MILLISECONDS - Static variable in class org.apache.hadoop.hbase.hbtop.screen.Screen
-
- sleepBeforeFailover - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- sleepBeforeRetry(String, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
sleeping logic; handles the interrupt exception.
- sleepBeforeRetry(String, int, int, int) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
sleeping logic for static methods; handles the interrupt exception.
- sleeper - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- Sleeper - Class in org.apache.hadoop.hbase.util
-
Sleeper for current thread.
- Sleeper(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
-
- sleepForMs - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- sleepForRetries - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Do the sleeping logic
- sleepForRetries - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the sleeping logic
- sleepForRetries - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
Do the sleeping logic
- sleepForRetries - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- sleepIgnoreInterrupt(int) - Static method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
-
- sleepInterrupted(long) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- sleepInterval - Variable in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- sleepLock - Variable in class org.apache.hadoop.hbase.client.DelayingRunner
-
- sleepLock - Variable in class org.apache.hadoop.hbase.util.Sleeper
-
- sleepMsBeforeReCompare - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- sleepMsBeforeReCompare - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- sleepTime - Variable in class org.apache.hadoop.hbase.client.DelayingRunner
-
- sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
Sleep for a back off time as supplied by the backoff policy, and increases the attempts
- sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sleeps for the given amount of time even if interrupted.
- slice() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
-
Returns an ByteBuff which is a sliced version of this ByteBuff.
- slice() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
-
Returns an MBB which is a sliced version of this MBB.
- slice() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
-
- slop - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- sloppyRegionServerExist(ClusterLoadState) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- sloppyStores - Variable in class org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
-
- slotCond - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- slotIndex - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- slots - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- slotsCache - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- SLOW_APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_APPEND_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_DELETE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_GET_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_INCREMENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_LOG_BUFFER_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SLOW_LOG_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.RpcLogDetails
-
- SLOW_LOG_RING_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- SLOW_LOG_SYS_TABLE_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SLOW_LOG_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
hbase:slowlog table name - can be enabled with config -
hbase.regionserver.slowlog.systable.enabled
- SLOW_METRIC_TIME - Static variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- SLOW_PUT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- SLOW_SYNC_ROLL_INTERVAL_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- SLOW_SYNC_ROLL_REQUESTED - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_SYNC_ROLL_REQUESTED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_SYNC_ROLL_THRESHOLD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- SLOW_SYNC_TIME_MS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- SLOW_THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
- slowAppend - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- slowAppendCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- slowDataTtl - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- slowDelete - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- slowGet - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- slowIncrement - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- SLOWLOG_INFO_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The slowlog info family
- SLOWLOG_INFO_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The slowlog info family as a string
- SlowLogMasterService - Class in org.apache.hadoop.hbase.master.slowlog
-
Slowlog Master services - Table creation to be used by HMaster
- SlowLogMasterService(Configuration, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.slowlog.SlowLogMasterService
-
- SlowLogParams - Class in org.apache.hadoop.hbase.client
-
SlowLog params object that contains detailed info as params and region name : to be used for
filter purpose
- SlowLogParams(String, String) - Constructor for class org.apache.hadoop.hbase.client.SlowLogParams
-
- SlowLogParams(String) - Constructor for class org.apache.hadoop.hbase.client.SlowLogParams
-
- slowLogPayloads - Variable in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
-
- slowLogPersistentService - Variable in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- SlowLogPersistentService - Class in org.apache.hadoop.hbase.namequeues
-
Persistent service provider for Slow/LargeLog events
- SlowLogPersistentService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
- slowLogQueue - Variable in class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- SlowLogQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
-
In-memory Queue service provider for Slow/LargeLog events
- SlowLogQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
-
- slowLogResponseRequest - Variable in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
-
- SlowLogTableAccessor - Class in org.apache.hadoop.hbase.slowlog
-
Slowlog Accessor to record slow/large RPC log identified at each RegionServer RpcServer level.
- SlowLogTableAccessor() - Constructor for class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
-
- slowlogTableEnabled - Variable in class org.apache.hadoop.hbase.master.slowlog.SlowLogMasterService
-
- SlowLogTableOpsChore - Class in org.apache.hadoop.hbase.namequeues
-
Chore to insert multiple accumulated slow/large logs to hbase:slowlog system table
- SlowLogTableOpsChore(Stoppable, int, NamedQueueRecorder) - Constructor for class org.apache.hadoop.hbase.namequeues.SlowLogTableOpsChore
-
Chore Constructor
- slowLogTableOpsChore - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- slowMetricTime - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- slowPacketAckMs - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- slowPut - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- slowResponseTime - Variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- slowSyncCheckInterval - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- slowSyncCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- slowSyncNs - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- slowSyncRollRequested - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- slowSyncRollThreshold - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- small - Variable in class org.apache.hadoop.hbase.client.Scan
-
Set it true for small scan to get better performance Small scan should use pread and big scan
can use seek + read seek + read is fast but can cause two problem (1) resource contention (2)
cause too much network io [89-fb] Using pread for non-compaction read request
https://issues.apache.org/jira/browse/HBASE-7266 On the other hand, if setting it true, we
would do openScanner,next,closeScanner in one RPC call.
- SMALL_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SMALL_COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SMALL_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- SMALL_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- SMALL_HFILE_DELETE_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- SMALL_HFILE_QUEUE_INIT_SIZE - Static variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- smallFileDeleteThreadNumber - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- smallFileQueue - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- smallQueueInitSize - Variable in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- sn - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- sn - Variable in class org.apache.hadoop.hbase.master.balancer.ServerAndLoad
-
- SNAPPY_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- SNAPPY_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- SNAPPY_CODEC_CLASS_DEFAULT - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
-
- SNAPPY_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.io.compress.Compression
-
- SnappyCodec - Class in org.apache.hadoop.hbase.io.compress.aircompressor
-
Hadoop snappy codec implemented with aircompressor.
- SnappyCodec() - Constructor for class org.apache.hadoop.hbase.io.compress.aircompressor.SnappyCodec
-
- SnappyCodec - Class in org.apache.hadoop.hbase.io.compress.xerial
-
Hadoop Snappy codec implemented with Xerial Snappy.
- SnappyCodec() - Constructor for class org.apache.hadoop.hbase.io.compress.xerial.SnappyCodec
-
- SnappyCodec.HadoopSnappyCompressor - Class in org.apache.hadoop.hbase.io.compress.aircompressor
-
- SnappyCodec.HadoopSnappyDecompressor - Class in org.apache.hadoop.hbase.io.compress.aircompressor
-
- SnappyCompressor - Class in org.apache.hadoop.hbase.io.compress.xerial
-
Hadoop compressor glue for Xerial Snappy.
- SnappyCompressor(int) - Constructor for class org.apache.hadoop.hbase.io.compress.xerial.SnappyCompressor
-
- SnappyDecompressor - Class in org.apache.hadoop.hbase.io.compress.xerial
-
Hadoop decompressor glue for Xerial Snappy.
- SnappyDecompressor(int) - Constructor for class org.apache.hadoop.hbase.io.compress.xerial.SnappyDecompressor
-
- snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot for the given table.
- snapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(String, TableName, SnapshotType, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(String, TableName, Map<String, Object>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot for the given table.
- snapshot(String, TableName, SnapshotType) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Create typed snapshot of the table.
- snapshot(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Take a snapshot and wait for the server to complete that snapshot asynchronously.
- snapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- snapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- snapshot - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Triggers an asynchronous attempt to take a snapshot.
- snapshot - Variable in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- snapshot - Variable in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
-
- snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
- snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshot() - Method in interface org.apache.hadoop.hbase.metrics.Histogram
-
Snapshot the current values in the Histogram
- snapshot() - Method in class org.apache.hadoop.hbase.metrics.impl.HistogramImpl
-
- Snapshot - Interface in org.apache.hadoop.hbase.metrics
-
A statictical sample of histogram values.
- snapshot - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- snapshot - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- snapshot() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
Push the current active memstore segment into the pipeline and create a snapshot of the tail of
current compaction pipeline Snapshot must be cleared by call to
AbstractMemStore.clearSnapshot(long)
.
- snapshot() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Creates a snapshot of the current memstore.
- snapshot - Variable in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- snapshot() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Creates a snapshot of the current memstore.
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
-
- snapshot - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- SNAPSHOT - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
-
- SNAPSHOT - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.Options
-
- snapshot - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- snapshot(String, TableName, SnapshotType) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- snapshot(SnapshotDescription) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Sample all the mutable metrics and put the snapshot in the builder
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- snapshot(String, String, Histogram, MetricsRecordBuilder, boolean) - Static method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
- snapshot() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Get a snapshot of the current values of all the tracked quantiles.
- SNAPSHOT_CLEANER_CHORE_NAME - Static variable in class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
- SNAPSHOT_CLEANER_DEFAULT_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
- SNAPSHOT_CLEANER_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
- SNAPSHOT_CLONE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_CLONE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of the directory to store all snapshots.
- SNAPSHOT_INPUTFORMAT_LOCALITY_BY_REGION_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to calculate the Snapshot region location by region location from meta.
- SNAPSHOT_INPUTFORMAT_LOCALITY_BY_REGION_LOCATION_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- SNAPSHOT_INPUTFORMAT_LOCALITY_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- SNAPSHOT_INPUTFORMAT_LOCALITY_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to calculate the block location for splits.
- SNAPSHOT_INPUTFORMAT_ROW_LIMIT_PER_INPUTSPLIT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
In some scenario, scan limited rows on each InputSplit for sampling data extraction
- SNAPSHOT_INPUTFORMAT_SCAN_METRICS_ENABLED - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Whether to enable scan metrics on Scan, default to true
- SNAPSHOT_INPUTFORMAT_SCAN_METRICS_ENABLED_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- SNAPSHOT_INPUTFORMAT_SCANNER_READTYPE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
The
Scan.ReadType
which should be set on the
Scan
to read the HBase Snapshot,
default STREAM.
- SNAPSHOT_INPUTFORMAT_SCANNER_READTYPE_DEFAULT - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Version of the fs layout for a snapshot.
- SNAPSHOT_MANIFEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- SNAPSHOT_MANIFEST_SIZE_LIMIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- SNAPSHOT_MAX_FILE_SIZE_PRESERVE - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Conf key for preserving original max file size configs
- SNAPSHOT_NAME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- SNAPSHOT_NOTIFIER_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- SNAPSHOT_NOTIFIER_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- SNAPSHOT_OBSERVER_CHORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_OBSERVER_CHORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_OBSERVER_FETCH_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_OBSERVER_FETCH_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_OBSERVER_SIZE_COMPUTATION_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_OBSERVER_SIZE_COMPUTATION_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
-
- SNAPSHOT_POOL_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
number of current operations running on the master
- SNAPSHOT_POOL_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Conf key for # of threads used by the SnapshotManager thread pool
- SNAPSHOT_QUOTA_CHORE_DELAY_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SNAPSHOT_QUOTA_CHORE_DELAY_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SNAPSHOT_QUOTA_CHORE_PERIOD_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SNAPSHOT_QUOTA_CHORE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SNAPSHOT_QUOTA_CHORE_TIMEUNIT_DEFAULT - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SNAPSHOT_QUOTA_CHORE_TIMEUNIT_KEY - Static variable in class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- 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_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Default amount of time to check for errors while regions finish snapshotting
- 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_RESTORE_DIRECTORY_PERMISSION - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- SNAPSHOT_RESTORE_DIRECTORY_PERMISSION_DEFAULT - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- SNAPSHOT_RESTORE_FAILSAFE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SNAPSHOT_RESTORE_TAKE_FAILSAFE_SNAPSHOT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SNAPSHOT_RESTORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_RESTORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_RESTORE_TMP_DIR - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- SNAPSHOT_RESTORE_TMP_DIR_DEFAULT - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- SNAPSHOT_SENTINELS_CLEANUP_TIMEOUT_MILLS_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- SNAPSHOT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Keep threads alive in request pool for max of 300 seconds
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for max time to keep threads in snapshot request pool waiting
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SNAPSHOT_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Temporary directory under the snapshot directory to store in-progress snapshots
- SNAPSHOT_TO_SCANS_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
-
- SNAPSHOT_WAKE_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
By default, check to see if the snapshot is complete every WAKE MILLIS (ms)
- SNAPSHOT_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Conf key for # of ms elapsed between checks for snapshot errors while waiting for completion.
- SNAPSHOT_WORKING_DIR - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
The configuration property that determines the filepath of the snapshot base working directory
- snapshotAcl(SnapshotDescription) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
Set acl when take a snapshot
- snapshotAllMetrics(MetricRegistry, MetricsCollector) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
Iterates over the MetricRegistry and adds them to the collector
.
- snapshotAllMetrics(MetricRegistry, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
-
Iterates over the MetricRegistry and adds them to the builder
.
- snapshotAlreadyRestored - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- snapshotAndReset() - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
-
Resets the histogram for new counting.
- snapshotAsync(SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot without waiting for the server to complete that snapshot (asynchronous) Only a
single snapshot should be taken at a time, or results may be undefined.
- snapshotAsync(SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshotAsync(SnapshotDescription) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- SnapshotCleanerChore - Class in org.apache.hadoop.hbase.master.cleaner
-
This chore, every time it runs, will try to delete snapshots that are expired based on TTL in
seconds configured for each Snapshot
- SnapshotCleanerChore(Stoppable, Configuration, SnapshotManager) - Constructor for class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
Construct Snapshot Cleaner Chore with parameterized constructor
- snapshotCleanerChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn on or off the auto snapshot cleanup based on TTL.
- snapshotCleanupSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn on or off the auto snapshot cleanup based on TTL.
- snapshotCleanupSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- snapshotCleanupSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshotCleanupSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- snapshotCleanupSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- snapshotCleanupTracker - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- SnapshotCleanupTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks status of snapshot auto cleanup based on TTL
- SnapshotCleanupTracker(ZKWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.SnapshotCleanupTracker
-
Constructs a new ZK node tracker.
- snapshotCleanupZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- snapshotCloneTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
- SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Used internally by the RPC engine to pass the exception back to the client.
- SnapshotCreationException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot.
- SnapshotCreationException(String, Throwable, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause.
- snapshotDesc - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure.RegionSnapshotTask
-
- snapshotDesc - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- SnapshotDescription - Class in org.apache.hadoop.hbase.client
-
The POJO equivalent of HBaseProtos.SnapshotDescription
- SnapshotDescription(String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType, String) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, String, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType, String, long, int) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotDescription(String, TableName, SnapshotType, String, long, int, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
SnapshotDescription Parameterized Constructor
- SnapshotDescription(String, TableName, SnapshotType, Map<String, Object>) - Constructor for class org.apache.hadoop.hbase.client.SnapshotDescription
-
SnapshotDescription Parameterized Constructor
- SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help manage SnapshotDesriptions
.
- SnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
-
Filter that only accepts completed snapshot directories
- snapshotDir - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- snapshotDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshotDir - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
-
- snapshotDir - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- snapshotDir - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- SnapshotDirectoryInfo(long, Collection<String>) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.SnapshotDirectoryInfo
-
- snapshotDisabledRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Take a snapshot of the specified disabled region
- snapshotDisabledTable(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Take a snapshot of a disabled table.
- SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
- SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotDoesNotExistException(SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- snapshotEnabledTable(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Take a snapshot of an enabled table.
- SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot exists, but should not.
- SnapshotExistsException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing.
- SnapshotExistsException(String, SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing.
- SnapshotFileCache - Class in org.apache.hadoop.hbase.master.snapshot
-
Intelligently keep track of all the files for all the snapshots.
- SnapshotFileCache(Configuration, 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(FileSystem, Path, 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.SnapshotDirectoryInfo - Class in org.apache.hadoop.hbase.master.snapshot
-
Information about a snapshot directory
- SnapshotFileCache.SnapshotFileInspector - Interface in org.apache.hadoop.hbase.master.snapshot
-
- snapshotHandlerChoreCleanerTask - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- snapshotHandlers - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- 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
-
- snapshotId - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
-
- snapshotImmutableSegment - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- SnapshotInfo.Options - Class in org.apache.hadoop.hbase.snapshot
-
- SnapshotInfo.SnapshotStats - Class in org.apache.hadoop.hbase.snapshot
-
Statistics about the snapshot
How many store files and logs are in the archive
How many store files and logs are shared with the table
Total store files and logs size and shared amount
- SnapshotInfo.SnapshotStats.FileInfo - Class in org.apache.hadoop.hbase.snapshot
-
Information about the file referenced by the snapshot
- 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.
- snapshotManager - Variable in class org.apache.hadoop.hbase.master.cleaner.SnapshotCleanerChore
-
- snapshotManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- 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, ProcedureCoordinator, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Fully specify all necessary components of a snapshot manager.
- snapshotManager - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshotManifest - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshotManifest - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- snapshotManifest - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- SnapshotManifest - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help read/write the Snapshot Manifest.
- SnapshotManifest(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, ForeignExceptionSnare, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- SnapshotManifest.RegionVisitor<TRegion,TFamily> - Interface in org.apache.hadoop.hbase.snapshot
-
- SnapshotManifestV1 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV1() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
-
- SnapshotManifestV1.ManifestBuilder - Class in org.apache.hadoop.hbase.snapshot
-
- SnapshotManifestV2 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV2() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- SnapshotManifestV2.ManifestBuilder - Class in org.apache.hadoop.hbase.snapshot
-
- snapshotMobRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
Takes a snapshot of the mob region
- snapshotName - Variable in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- snapshotName - Variable in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- snapshotName - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- snapshotName - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- snapshotNotifier - Variable in class org.apache.hadoop.hbase.quotas.QuotaObserverChore
-
- snapshotObserverSizeComputationTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- snapshotObserverSnapshotFetchTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- snapshotObserverTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- SnapshotOfRegionAssignmentFromMeta - Class in org.apache.hadoop.hbase.master
-
Used internally for reading meta and constructing datastructures that are then queried, for
things like regions to regionservers, table to regions, etc.
- SnapshotOfRegionAssignmentFromMeta(Connection) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- SnapshotOfRegionAssignmentFromMeta(Connection, Set<TableName>, boolean) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- snapshotQuotaChore - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- SnapshotQuotaObserverChore - Class in org.apache.hadoop.hbase.quotas
-
A Master-invoked Chore
that computes the size of each snapshot which was created from a
table which has a space quota.
- SnapshotQuotaObserverChore(HMaster, MetricsMaster) - Constructor for class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SnapshotQuotaObserverChore(Connection, Configuration, FileSystem, Stoppable, MetricsMaster) - Constructor for class org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
-
- SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
-
Utility methods for interacting with the snapshot referenced files.
- SnapshotReferenceUtil() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
- SnapshotReferenceUtil.SnapshotVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- SnapshotReferenceUtil.StoreFileVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- snapshotRegions(List<Pair<RegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- snapshotRegions(List<Pair<RegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
This method kicks off a snapshot procedure.
- snapshotRegions(List<Pair<RegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Snapshot the specified regions
- snapshotRegionSizes() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- snapshotRestoreTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- snapshots - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
This is a helper map of information about the snapshot directories so we don't need to rescan
them if they haven't changed since the last time we looked.
- snapshots - Variable in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
-
- SnapshotScannerHDFSAclCleaner - Class in org.apache.hadoop.hbase.security.access
-
Implementation of a file cleaner that checks if a empty directory with no subdirs and subfiles is
deletable when user scan snapshot feature is enabled
- SnapshotScannerHDFSAclCleaner() - Constructor for class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclCleaner
-
- SnapshotScannerHDFSAclController - Class in org.apache.hadoop.hbase.security.access
-
Set HDFS ACLs to hFiles to make HBase granted users have permission to scan snapshot
- SnapshotScannerHDFSAclController() - Constructor for class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
-
- SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage - Class in org.apache.hadoop.hbase.security.access
-
- SnapshotScannerHDFSAclHelper - Class in org.apache.hadoop.hbase.security.access
-
A helper to modify or remove HBase granted user default and access HDFS ACLs over hFiles.
- SnapshotScannerHDFSAclHelper(Configuration, Connection) - Constructor for class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
-
- SnapshotScannerHDFSAclHelper.HDFSAclOperation - Class in org.apache.hadoop.hbase.security.access
-
Inner class used to describe modify or remove what type of acl entries(ACCESS, DEFAULT,
ACCESS_AND_DEFAULT) for files or directories(and child files).
- SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType - Enum in org.apache.hadoop.hbase.security.access
-
- SnapshotScannerHDFSAclHelper.HDFSAclOperation.Operation - Interface in org.apache.hadoop.hbase.security.access
-
- SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType - Enum in org.apache.hadoop.hbase.security.access
-
- SnapshotScannerHDFSAclHelper.PathHelper - Class in org.apache.hadoop.hbase.security.access
-
- SnapshotScannerHDFSAclStorage() - Constructor for class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
-
- SnapshotSegmentScanner - Class in org.apache.hadoop.hbase.regionserver
-
A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a
single pass, no reverse scanning or inserts happening.
- SnapshotSegmentScanner(ImmutableSegment) - Constructor for class org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
-
- SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
-
Watch the current snapshot under process
- snapshotSkipFlush - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- SnapshotStats(Configuration, FileSystem, SnapshotDescription) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- SnapshotStats(Configuration, FileSystem, SnapshotProtos.SnapshotDescription) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- SnapshotSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
-
- SnapshotSubprocedurePool(String, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
- snapshotTable(SnapshotProtos.SnapshotDescription, TakeSnapshotHandler) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Take a snapshot using the specified handler.
- snapshotTable - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshotTable - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- snapshotTable - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- snapshotTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- snapShotType - Variable in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- SnapshotType - Enum in org.apache.hadoop.hbase.client
-
POJO representing the snapshot type
- SnapshotType() - Constructor for enum org.apache.hadoop.hbase.client.SnapshotType
-
- snapshotType - Variable in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- SnapshotWithSize(String, long) - Constructor for class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.SnapshotWithSize
-
- sniff(CanaryTool.RegionTask.TaskType, CanaryTool.RegionStdOutSink) - Method in class org.apache.hadoop.hbase.tool.CanaryTool.RegionMonitor
-
- sniff(Admin, CanaryTool.Sink, String, ExecutorService, CanaryTool.RegionTask.TaskType, boolean, LongAdder, boolean) - Static method in class org.apache.hadoop.hbase.tool.CanaryTool
-
Canary entry point for specified table.
- sniff(Admin, CanaryTool.Sink, TableDescriptor, ExecutorService, CanaryTool.RegionTask.TaskType, boolean, LongAdder, boolean) - Static method in class org.apache.hadoop.hbase.tool.CanaryTool
-
- socket - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
-
- socket - Variable in class org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
-
Deprecated.
- SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The delay when re-trying a socket operation in a loop (HBASE-4712)
- SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
How long we wait when we wait for an answer.
- SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- socketFactory - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcClient
-
- socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
- socketTimeoutMultiplier - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- SoftObjectPool<K,V> - Class in org.apache.hadoop.hbase.util
-
A SoftReference
based shared object pool.
- SoftObjectPool(ObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
-
- SoftObjectPool(ObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
-
- SoftObjectPool(ObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool
-
- SoftObjectPool.SoftObjectReference - Class in org.apache.hadoop.hbase.util
-
- SoftObjectReference(K, V) - Constructor for class org.apache.hadoop.hbase.util.SoftObjectPool.SoftObjectReference
-
- solve() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Get the optimal assignments.
- someRPCcancelled - Variable in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
- sortAndMerge(List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
sort the ranges and if the ranges with overlap, then merge them.
- sortByConsumedSpace(List<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Sort the given list in (descending) order of the space each element takes
- sortColumns - Variable in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
-
- SORTED_ORDINAL_SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Visibility serialization version format.
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Byte representation of the visibility_serialization_version
- sortedAndMergedRanges - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RangeIteration
-
- SortedCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
An abstract compaction policy that select files on seq id order.
- SortedCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.SortedCompactionPolicy
-
- 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.
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- sortField - Variable in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- sortServersByRegionCount() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
-
- sortTagsBasedOnOrdinal(List<Tag>) - Static method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- source - Variable in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Name of the throwable's source such as a host or thread name.
- source - Variable in class org.apache.hadoop.hbase.io.MetricsIO
-
- source - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- source - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- source - Variable in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
- source - Variable in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
- source - Variable in class org.apache.hadoop.hbase.master.RegionPlan
-
- source - Variable in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
Name of the throwable's source such as a host or thread name.
- source - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
-
- source - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- source - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
-
- source - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
-
- source - Variable in enum org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl.SourceHolder
-
- source - Variable in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
-
- source - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceLogQueue
-
- source - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- source - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- source - Variable in class org.apache.hadoop.hbase.rest.MetricsREST
-
- source - Variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- SOURCE_AGE_OF_LAST_SHIPPED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_CLOSED_LOGS_WITH_UNKNOWN_LENGTH - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_COMPLETED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_COMPLETED_RECOVERY_QUEUES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_FAILED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_FAILED_RECOVERY_QUEUES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_HASH_DIR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- SOURCE_INITIALIZING - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_LOG_EDITS_FILTERED - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_LOG_READ_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_LOG_READ_IN_EDITS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_REPEATED_LOG_FILE_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_RESTARTED_LOG_READING - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_HFILES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_KBS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
Deprecated.
- SOURCE_SHIPPED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SIZE_OF_HFILE_REFS_QUEUE - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SIZE_OF_LOG_QUEUE - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- SOURCE_UNCLEANLY_CLOSED_IGNORED_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_UNCLEANLY_CLOSED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_WAL_READER_EDITS_BUFFER - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- SOURCE_ZK_CLUSTER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- sourceBaseNamespaceDirPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- sourceClusterConf - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- sourceClusterIds - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- sourceClustersConfs - Variable in class org.apache.hadoop.hbase.replication.regionserver.DefaultSourceFSConfigurationProvider
-
- sourceConnection - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- sourceConnection - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- sourceFs - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator.Copier
-
- SourceFSConfigurationProvider - Interface in org.apache.hadoop.hbase.replication.regionserver
-
Interface that defines how a region server in peer cluster will get source cluster file system
configurations.
- sourceHashDir - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- sourceHashDir - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- sourceHashReader - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- sourceHFileArchiveDirPath - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator
-
- SourceHolder() - Constructor for enum org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl.SourceHolder
-
- sourceInitializing - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
-
- sourceInitializing - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sourceInitializingKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- sourceIterator - Variable in class org.apache.hadoop.hbase.master.http.MetaBrowser.Results
-
- sourceName - Variable in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- sourceNamesField - Variable in class org.apache.hadoop.metrics2.lib.DefaultMetricsSystemHelper
-
- sourceRunning - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- sources - Variable in enum org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl.SourceStorage
-
- sources - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
- sources - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- sources - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- sourceScanner - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
-
Source scanner that is tracking KV count; may be null if source is not StoreScanner
- sourceServer - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
-
- sourceServer - Variable in class org.apache.hadoop.hbase.util.MoveWithoutAck
-
- sourceSnapshotName - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- sourceSnapshotTmpDir - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- SourceStorage() - Constructor for enum org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl.SourceStorage
-
- sourceTable - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- sourceTable - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- sourceTableHash - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- sourceTableName - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- sourceToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sourceToString
- sourceValue - Variable in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- sourceZkCluster - Variable in class org.apache.hadoop.hbase.mapreduce.SyncTable
-
- SPACE - Static variable in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
-
- SPACE_QUOTA_REFRESHER_CHORE_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
-
- SpaceLimitingException - Exception in org.apache.hadoop.hbase.quotas
-
An Exception that is thrown when a space quota is in violation.
- SpaceLimitingException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- SpaceLimitingException(String, String) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- SpaceLimitingException(String, String, Throwable) - Constructor for exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
-
- SpaceLimitSettings - Class in org.apache.hadoop.hbase.quotas
-
A
QuotaSettings
implementation for configuring filesystem-use quotas.
- SpaceLimitSettings(TableName, long, SpaceViolationPolicy) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- SpaceLimitSettings(TableName) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
Constructs a SpaceLimitSettings
to remove a space quota on the given tableName
.
- SpaceLimitSettings(String, long, SpaceViolationPolicy) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- SpaceLimitSettings(String) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
Constructs a SpaceLimitSettings
to remove a space quota on the given namespace
.
- SpaceLimitSettings(TableName, String, QuotaProtos.SpaceLimitRequest) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- spaceProto - Variable in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- spaceQuotaRefresher - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- SpaceQuotaRefresherChore - Class in org.apache.hadoop.hbase.quotas
-
- SpaceQuotaRefresherChore(RegionServerSpaceQuotaManager, Connection) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
-
- spaceQuotaRefresherChoreTimer - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- spaceQuotasGauge - Variable in class org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
-
- SpaceQuotaSnapshot - Class in org.apache.hadoop.hbase.quotas
-
A point-in-time view of a space quota on a table.
- SpaceQuotaSnapshot(SpaceQuotaSnapshot.SpaceQuotaStatus, long, long) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
-
- SpaceQuotaSnapshot.SpaceQuotaStatus - Class in org.apache.hadoop.hbase.quotas
-
Encapsulates the state of a quota on a table.
- spaceQuotaSnapshotNotifier - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- SpaceQuotaSnapshotNotifier - Interface in org.apache.hadoop.hbase.quotas
-
An interface which abstract away the action taken to enable or disable a space quota violation
policy across the HBase cluster.
- SpaceQuotaSnapshotNotifierFactory - Class in org.apache.hadoop.hbase.quotas
-
- SpaceQuotaSnapshotNotifierFactory() - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
-
- spaceQuotaSnapshotsReceived - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
-
- SpaceQuotaSnapshotView - Interface in org.apache.hadoop.hbase.quotas
-
A point-in-time view of a space quota on a table, read only.
- SpaceQuotaSnapshotView.SpaceQuotaStatusView - Interface in org.apache.hadoop.hbase.quotas
-
Encapsulates the state of a quota on a table.
- SpaceQuotaStatus(SpaceViolationPolicy) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
Constructs a SpaceQuotaSnapshot
which is in violation of the provided policy
.
- SpaceQuotaStatus(SpaceViolationPolicy, boolean) - Constructor for class org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
-
- SpaceViolationPolicy - Enum in org.apache.hadoop.hbase.quotas
-
Enumeration that represents the action HBase will take when a space quota is violated.
- SpaceViolationPolicy() - Constructor for enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
- SpaceViolationPolicyEnforcement - Interface in org.apache.hadoop.hbase.quotas
-
- SpaceViolationPolicyEnforcementFactory - Class in org.apache.hadoop.hbase.quotas
-
- SpaceViolationPolicyEnforcementFactory() - Constructor for class org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
-
- span - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- span - Variable in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- span - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- span - Variable in class org.apache.hadoop.hbase.ipc.Call
-
- span - Variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- span - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- SPARK - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- spawnRenewalChore(UserGroupInformation) - Method in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- spawnRenewalChore(UserGroupInformation) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- SPECIAL_RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is for for using HRegion as a local storage, where we may put the recovered edits in a
special place.
- specialEndKey(R) - Static method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
SPECIAL CASE wrapper for empty end key
- SPECIFIC_WRITE_THREAD - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- split(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split a table.
- split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split a table.
- split(TableName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- split(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split - Variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- split(TableName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- split(RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- split - Variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- split - Variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- split - Variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- split(Configuration, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- split(TableName) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split a pre-existing region into 2 regions.
- split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split an entire table.
- split(byte[], byte[], int, boolean) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Some MapReduce jobs may want to run multiple mappers per region, this is intended for such
usecase.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(byte[], byte[], int, boolean) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(Path, Path, Path, FileSystem, Configuration, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Split a folder of WAL files.
- split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
Divide 2 numbers in half (for split algorithm)
- SPLIT_ALGO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
For MapReduce jobs running multiple mappers per region, determines what split algorithm we
should be using to find split points for scanners.
- SPLIT_ENABLED - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
Used by HBase Shell interface to access this metadata attribute which denotes if the table is
split enabled.
- SPLIT_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- SPLIT_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- SPLIT_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
- SPLIT_IGNORE_BLOCKING_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Config for allow split when file count greater than the configured blocking file count
- SPLIT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the splitlog directory for a region server
- SPLIT_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- SPLIT_PARTS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The target count of new stripes to produce when splitting a stripe.
- SPLIT_PLAN_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SPLIT_PLAN_COUNT_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
-
- SPLIT_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_REGION_COMPACTION_PRIORITY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- SPLIT_REQUEST_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
By default we retry errors in splitting, rather than skipping.
- SPLIT_SKIP_ERRORS_KEY - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- SPLIT_SUCCESS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_SUCCESS_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
If specified, use start keys of this table to split.
- SPLIT_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- SPLIT_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_WAL_BUFFER_SIZE - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- SPLIT_WAL_WRITER_THREADS - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- SPLIT_WRITER_CREATION_BOUNDED - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
True if we are to run with bounded amount of writers rather than let the count blossom.
- splitA - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier
- SPLITA_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier string.
- splitAndResolveOperation(ServerName, Set<RemoteProcedureDispatcher.RemoteProcedure>, RSProcedureDispatcher.RemoteProcedureResolver) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- splitB - Variable in class org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
-
- SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier
- SPLITB_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier String.
- splitCell - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitEnabled - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizerConfiguration
-
- splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Splitting fully qualified Kerberos name into parts
- splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitkey - Variable in class org.apache.hadoop.hbase.io.Reference
-
- splitKeyFromHBase(byte[][]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- splitKeyFromThrift(List<ByteBuffer>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- splitKeys - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.CreateTableFuture
-
- splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- splitLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
- splitLog(Set<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
This method is the base split method that splits WAL files matching a filter.
- splitLog(String, CancelableProgressable, Configuration, RegionServerServices, LastSequenceId, WALFactory) - Static method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
Returns Result either DONE, RESIGNED, or ERR.
- SplitLogCounters - Class in org.apache.hadoop.hbase
-
- SplitLogCounters() - Constructor for class org.apache.hadoop.hbase.SplitLogCounters
-
Deprecated.
- splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
The caller will block until all the log files of the given region server have been processed -
successfully split or an error is encountered - by an available worker region server.
- splitLogDistributed(Set<ServerName>, List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
The caller will block until all the hbase:meta log files of the given region server have been
processed - successfully split or an error is encountered - by an available worker region
server.
- splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable, LastSequenceId, SplitLogWorkerCoordination, WALFactory, RegionServerServices) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Splits a WAL file.
- splitLogLock - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- splitLogManager - Variable in class org.apache.hadoop.hbase.master.MasterWalManager
-
- SplitLogManager - Class in org.apache.hadoop.hbase.master
-
- SplitLogManager(MasterServices, Configuration) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
Its OK to construct this object even when region-servers are not online.
- SplitLogManager.ResubmitDirective - Enum in org.apache.hadoop.hbase.master
-
Deprecated.
- SplitLogManager.Task - Class in org.apache.hadoop.hbase.master
-
Deprecated.
in memory state of an active task.
- SplitLogManager.TaskBatch - Class in org.apache.hadoop.hbase.master
-
Deprecated.
Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
- SplitLogManager.TerminationStatus - Enum in org.apache.hadoop.hbase.master
-
Deprecated.
- SplitLogManager.TimeoutMonitor - Class in org.apache.hadoop.hbase.master
-
Deprecated.
Periodically checks all active tasks and resubmits the ones that have timed out
- SplitLogManagerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
- splitLogManagerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- SplitLogManagerCoordination.SplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
-
Deprecated.
Detail class that shares data between coordination and split log manager
- SplitLogManagerDetails(ConcurrentMap<String, SplitLogManager.Task>, MasterServices, Set<String>) - Constructor for class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
Deprecated.
- SplitLogTask - Class in org.apache.hadoop.hbase
-
- SplitLogTask(ZooKeeperProtos.SplitLogTask) - Constructor for class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- SplitLogTask(ServerName, ZooKeeperProtos.SplitLogTask.State) - Constructor for class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- SplitLogTask.Done - Class in org.apache.hadoop.hbase
-
Deprecated.
- SplitLogTask.Err - Class in org.apache.hadoop.hbase
-
Deprecated.
- SplitLogTask.Owned - Class in org.apache.hadoop.hbase
-
Deprecated.
- SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
-
Deprecated.
- SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
-
Deprecated.
- splitLogWorker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
-
- SplitLogWorker(Server, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- SplitLogWorker(Configuration, RegionServerServices, LastSequenceId, WALFactory) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
- SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
-
Deprecated.
Objects implementing this interface actually do the task that has been acquired by a
SplitLogWorker
.
- SplitLogWorker.TaskExecutor.Status - Enum in org.apache.hadoop.hbase.regionserver
-
Deprecated.
- SplitLogWorkerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
- splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
Deprecated.
- splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
Coordinator for split log.
- SplitLogWorkerCoordination.SplitTaskDetails - Interface in org.apache.hadoop.hbase.coordination
-
Deprecated.
Interface for log-split tasks Used to carry implementation details in encapsulated way through
Handlers to the coordination API.
- splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Specialized method to handle the splitting for meta WAL
- splitMetaLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
-
Specialized method to handle the splitting for meta WAL
- splitMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- SplitNormalizationPlan - Class in org.apache.hadoop.hbase.master.normalizer
-
Normalization plan to split a region.
- SplitNormalizationPlan(RegionInfo, long) - Constructor for class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
-
- splitOrMergeSwitch(boolean, boolean, MasterSwitchType) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitOrMergeTracker - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- SplitOrMergeTracker - Class in org.apache.hadoop.hbase.master
-
Tracks the switch of split and merge states in ZK
- SplitOrMergeTracker(ZKWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- SplitOrMergeTracker.SwitchStateTracker - Class in org.apache.hadoop.hbase.master
-
- SplitParentFirstComparator() - Constructor for class org.apache.hadoop.hbase.master.janitor.CatalogJanitor.SplitParentFirstComparator
-
- splitParentRegions - Variable in class org.apache.hadoop.hbase.master.hbck.HbckReport
-
- splitParents - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitorReport
-
- splitPartCount - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- splitPartSize - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- splitPlanCount - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- splitPolicy - Variable in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- splitPolicy - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- splitProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
-
- splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Split an individual region.
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- splitRegion(RpcController, MasterProtos.SplitTableRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- splitRegion(RegionInfo, RegionInfo, RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- splitRegion(RegionInfo, byte[], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- splitRegion(RpcController, MasterProtos.SplitTableRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- splitRegion(RegionInfo, byte[], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Split a region.
- splitRegion(Connection, RegionInfo, long, RegionInfo, RegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Splits the region into two in an atomic operation.
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- splitRegionAsync(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegionAsync(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegionAsync(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegionAsync(RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegionAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitRegionAsync(byte[], byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- splitRegionAsync(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- splitRegionInfo - Variable in class org.apache.hadoop.hbase.master.http.RegionReplicaInfo
-
- splitRegions - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
-
- splitRegions - Variable in class org.apache.hadoop.hbase.client.RegionStatesCount
-
- splitRegionSync(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split one region.
- splitRegionSync(byte[], byte[], long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split one region.
- splitRequest - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- splitRequest - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- SplitRequest - Class in org.apache.hadoop.hbase.regionserver
-
Handles processing region splits.
- SplitRequest(Region, byte[], HRegionServer, User) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitRequest
-
- splitRestriction - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- splits - Variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- splits - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- splits - Variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
This contains a sorted set of all the possible split points Invariant: once populated this has
0 entries if empty or at most n+1 values where n == number of added ranges.
- splits - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
List of all the files produced by this sink
- splitScan(LinkedList<Pair<byte[], byte[]>>, Connection, TableName, RegionSplitter.SplitAlgorithm) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter
-
- splitSizeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- splitStateTracker - Variable in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- splitStoreFile(HRegionFileSystem, byte[], HStoreFile) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- splitStoreFile(RegionInfo, String, HStoreFile, byte[], boolean, RegionSplitPolicy) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Write out a split reference.
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
- splitStoreFile(Configuration, Path, ColumnFamilyDescriptor, byte[], Path, Path) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Split a storefile into a top and bottom half, maintaining the metadata, recreating bloom
filters, etc.
- splitStoreFiles(MasterProcedureEnv, HRegionFileSystem) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
Create Split directory
- SplitStripeCompactionRequest(CompactionRequestImpl, byte[], byte[], int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.SplitStripeCompactionRequest
-
- SplitStripeCompactionRequest(Collection<HStoreFile>, byte[], byte[], long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.SplitStripeCompactionRequest
-
- SplitStripeCompactionRequest(Collection<HStoreFile>, byte[], byte[], int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.SplitStripeCompactionRequest
-
- splitSuccess - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- splitSuccess - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the split switch on or off.
- splitSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- splitSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Turn the Split switch on or off.
- splitSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- splitSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- splitSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- splitSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- SplitTableRegionFuture(HBaseAdmin, TableName, MasterProtos.SplitTableRegionResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.SplitTableRegionFuture
-
- SplitTableRegionFuture(HBaseAdmin, TableName, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.SplitTableRegionFuture
-
- SplitTableRegionProcedure - Class in org.apache.hadoop.hbase.master.assignment
-
The procedure to split a region in a table.
- SplitTableRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- SplitTableRegionProcedure(MasterProcedureEnv, RegionInfo, byte[]) - Constructor for class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
-
- SplitTableRegionProcedure.StoreFileSplitter - Class in org.apache.hadoop.hbase.master.assignment
-
Utility class used to do the file splitting / reference writing in parallel instead of
sequentially.
- SplitTableRegionProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.SplitTableRegionProcedureBiConsumer
-
- splitTarget - Variable in class org.apache.hadoop.hbase.master.normalizer.SplitNormalizationPlan
-
- splitTaskDetails - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- splitTaskExecutor - Variable in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- splitTaskExecutor - Variable in class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
Deprecated.
- splitTimeHisto - Variable in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- splitTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- splitTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
-
- SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
File Extension used while splitting an WAL into regions (HBASE-2312)
- splitWAL(FileStatus, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
WAL splitting implementation, splits one WAL file.
- SplitWALCallable - Class in org.apache.hadoop.hbase.regionserver
-
This callable is used to do the real split WAL task.
- SplitWALCallable() - Constructor for class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- SplitWALCallable.ErrorWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
-
- SplitWALCallable.PreemptedWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
-
- SplitWALCallable.ResignedWALSplitException - Exception in org.apache.hadoop.hbase.regionserver
-
- splitWALLock - Variable in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- splitWALLocks - Variable in class org.apache.hadoop.hbase.regionserver.SplitWALCallable
-
- splitWALManager - Variable in class org.apache.hadoop.hbase.master.HMaster
-
- SplitWALManager - Class in org.apache.hadoop.hbase.master
-
- SplitWALManager(MasterServices) - Constructor for class org.apache.hadoop.hbase.master.SplitWALManager
-
- SplitWALManager.SplitWorkerAssigner - Class in org.apache.hadoop.hbase.master
-
help assign and release a worker for each WAL splitting task For each worker, concurrent
running splitting task should be no more than maxSplitTasks If a task failed to acquire a
worker, it will suspend and wait for workers available
- SplitWALProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure is to split a WAL.
- SplitWALProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- SplitWALProcedure(String, ServerName) - Constructor for class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
-
- SplitWALRemoteProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
A remote procedure which is used to send split WAL request to region server.
- SplitWALRemoteProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- SplitWALRemoteProcedure(ServerName, ServerName, String) - Constructor for class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
-
- SplitWALResult(boolean, boolean) - Constructor for class org.apache.hadoop.hbase.wal.WALSplitter.SplitWALResult
-
- splitWALs(ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
-
- splitWorkerAssigner - Variable in class org.apache.hadoop.hbase.master.SplitWALManager
-
- SplitWorkerAssigner(MasterServices, int) - Constructor for class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- splitWriterCreationBounded - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- splitZnode - Variable in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- SPNEGO_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- SPNEGO_PROXYUSER_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- spread - Variable in class org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
-
- src - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- src - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- src - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- SRC_IMPL - Static variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.MigrationStoreFileTracker
-
- srcFs - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- sslEnabled - Variable in class org.apache.hadoop.hbase.rest.client.Client
-
- SslRMIClientSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIClientSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
-
- SslRMIServerSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIServerSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
-
- stack - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
-
- STACK_DEPTH - Static variable in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- stackIndexes - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- StackServlet() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.StackServlet
-
- stagingDir - Variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager.SecureBulkLoadListener
-
- stagingDir - Variable in class org.apache.hadoop.hbase.replication.regionserver.HFileReplicator.Copier
-
- stale - Variable in class org.apache.hadoop.hbase.client.Result
-
- STALE_CACHE_CLEAN_CHORE_INTERVAL_IN_MILLISECONDS - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- STALE_CACHE_TIMEOUT_IN_MILLISECONDS - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- staleCache - Variable in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- StaleLocationCacheEntry(byte[]) - Constructor for class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry
-
- staleRefQueue - Variable in class org.apache.hadoop.hbase.util.ObjectPool
-
- stamp - Variable in class org.apache.hadoop.hbase.master.RegionState
-
- stampRegionSequenceId(MultiVersionConcurrencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSWALEntry
-
Here is where a WAL edit gets its sequenceid.
- stampSequenceIdAndPublishToRingBuffer(RegionInfo, WALKeyImpl, WALEdit, boolean, RingBuffer<RingBufferTruck>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- standaloneServerFactoryList - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- standardizeZKQuorumServerString(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Standardize the ZK quorum string: make it a "server:clientport" list, separated by ','
- STAR - Static variable in class org.apache.hadoop.hbase.util.MunkresAssignment
-
- starInCol(int) - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Find a starred zero in the specified column.
- starInRow(int) - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Find a starred zero in a specified row.
- start() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Start monitoring for archive updates
- start() - Method in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- start(HBaseRpcController, ClientProtos.ScanResponse) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
Short cut for build().start(HBaseRpcController, ScanResponse)
.
- start(HBaseRpcController, ClientProtos.ScanResponse) - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
Now we will also fetch some cells along with the scanner id when opening a scanner, so we also
need to process the ScanResponse for the open scanner request.
- start() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- start() - Method in class org.apache.hadoop.hbase.client.RetryingTimeTracker
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- 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.example.BulkDeleteEndpoint
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleMasterObserverWithMetrics
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
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.example.ScanModifyingObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- start - Variable in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- start - Variable in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- start() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Start a timer to fail a process if it takes longer than the expected time to complete.
- start() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- start() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Start the server.
- start() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- start() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- start() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- start() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- 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 interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Starts the service.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
-
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- start() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- start() - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
-
Starts the tracking of draining RegionServers.
- start() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- start() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- start() - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
-
- start() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- start() - Method in class org.apache.hadoop.hbase.master.TableStateManager
-
- start() - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
Starts the syncer
- start() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- start() - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
-
Starts the NamespaceStateManager.
- start() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Start accepting flush table requests.
- start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
- start(String, ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Initialize and start any threads or connections the member needs.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Start accepting procedure requests.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- start(ProcedureCoordinator) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
-
Start monitoring znodes in ZK - subclass hook to start monitoring znodes they are about.
- start(String, ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- start() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- start() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Start the scheduler
- start() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- start(int) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Start/Open the procedure store
- start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- start - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
-
Deprecated.
Offset of bitmap i.e.
- start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotasObserver
-
- start() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- start(RpcScheduler) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- start() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- start(ChoreService) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- The request to dispatch
the compaction asynchronous task.
- start(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreFlusher
-
- start(ZKWatcher) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- 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
-
Deprecated.
start the SplitLogWorker thread
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- start(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- start(String) - Method in interface org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
-
Start the throughput controller.
- start() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- start() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initiates service startup and returns immediately.
- start() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- start() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
-
- start() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- 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.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 interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
- start() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- start() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- start() - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Mark start time of an execution.
- start() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
-
Starts the tracking of whether master is in Maintenance Mode.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
Starts the tracking of the node in ZooKeeper.
- START_BASE64 - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- START_KEYS - Static variable in class org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
-
- START_KEYS - Static variable in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparablePartitioner
-
Deprecated.
- START_LOG_ERRORS_AFTER_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
Configure the number of failures after which the client will start logging.
- START_LOG_ERRORS_AFTER_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
Configure the number of failures after which the client will start logging.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- startActiveMasterManager(int) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- startAssignmentThread() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- startBatch(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.mapreduce.HashTable.ResultHasher
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- startBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
-
- startBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- startBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- startBuffer - Variable in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- startBulkRegionOperation(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This method needs to be called before any public call that reads or modifies stores in bulk.
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- startCacheFlush(byte[], Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- startCacheFlush(byte[], Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
-
- startCacheFlush(byte[], Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- startCacheFlush(byte[], Set<byte[]>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
WAL keeps track of the sequence numbers that are as yet not flushed im memstores in order to be
able to do accounting to figure which WALs can be let go.
- startCacheFlush(byte[], Map<byte[], Long>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- startCancel() - Method in class org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
-
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
-
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
-
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- startCode - Variable in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- startcode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
This servers startcode.
- startCode - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- startCode - Variable in class org.apache.hadoop.hbase.ServerName
-
- STARTCODE_FIELD - Static variable in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- STARTCODE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- StartcodeAgnosticServerName - Class in org.apache.hadoop.hbase.favored
-
This class differs from ServerName in that start code is always ignored.
- StartcodeAgnosticServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.favored.StartcodeAgnosticServerName
-
- startCompaction(Admin, TableName, RegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.mob.MobFileCompactionChore
-
- startConnectorServer(int, int) - Method in class org.apache.hadoop.hbase.JMXListener
-
- started - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This flag is set to true after all threads are up and 'running' and the server is then opened
for business by the call to
RpcServerInterface.start()
.
- started(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterRegionServerList
-
- started - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- started(ServerName) - Method in interface org.apache.hadoop.hbase.master.RegionServerList
-
Called when a region server join the cluster.
- started - Variable in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- started - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- startExecutorService(ExecutorService.ExecutorConfig) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
Start an executor service with a given name.
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- startHandlers(String, int, List<BlockingQueue<CallRunner>>, int, int, int, AtomicInteger) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Start up our handlers.
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- startHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start the hbase cluster.
- startHBaseCluster() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- startHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- startHFileDeleteThreads() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Start threads for hfile deletion
- startHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
-
- startHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- startHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- startHour - Variable in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours.OffPeakHoursImpl
-
- startIdleScan() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- startIndex - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
-
- startInfoServer() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- startKey - Variable in class org.apache.hadoop.hbase.client.MutableRegionInfo
-
- startKey - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- startKey - Variable in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- startKey - Variable in class org.apache.hadoop.hbase.client.RegionInfoBuilder
-
- startKey - Variable in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
- startkey - Variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- startKey - Variable in class org.apache.hadoop.hbase.mob.MobFileName
-
- startKey - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
-
Key to seek to in memstore and StoreFiles
- startKey - Variable in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- STARTKEY_END_INDEX - Static variable in class org.apache.hadoop.hbase.mob.MobFileName
-
- startKeyInclusive - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- startKeys - Variable in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- startKeys - Variable in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
-
How many retries are allowed before we start to log
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncProcess
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BuilderBase
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
-
- startLogErrorsCnt(int) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- startLogErrorsCnt - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerImpl
-
How many retries are allowed before we start to log
- startMaster() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- startMaster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new master with localhost and random port.
- startMaster(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new master bind on the given host and port.
- startMaster() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- startMaster(String, int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- startMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionWindow
-
Inclusive lower bound
- startMillis() - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory.Window
-
- startMillis - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- startNewSubprocedure(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Kick off a new sub-procedure on the listener with the data stored in the passed znode.
- startNewSyncThread(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
- startNonceOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
Starts the nonce operation for a mutation, if needed.
- startNs - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
-
- startNs - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
-
- startOf(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- startOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
-
- startOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- startOffset - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Current block's start offset in the
HFile
.
- startOffset - Variable in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- 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.
- startPos - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Kick off the named procedure Currently only one procedure with the same type and name is
allowed to run at a time.
- startProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.MutationBatchOperation
-
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
-
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or modifies data.
- startRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or modifies data.
- startRegionServer() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new region server with localhost and random port.
- startRegionServer(String, int) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Start a new region server bind on the given host and port.
- startRegionServer() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- startRegionServer(String, int) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- startReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This message intends to inform the MemStore that next coming updates are going to be part of
the replaying edits from WAL
- startReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This message intends to inform the MemStore that next coming updates are going to be part of
the replaying edits from WAL
- startReplayingFromWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This message intends to inform the MemStore that next coming updates are going to be part of
the replaying edits from WAL
- startReplicationService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Start up replication source and sink handlers.
- 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
- startReplicationService() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- startRow - Variable in class org.apache.hadoop.hbase.client.Scan
-
- startRow - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- startRow - Variable in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- startRow - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- startRow - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- startRow - Variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- startRow - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.SplitStripeCompactionRequest
-
- startRow - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- startRowInclusive - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- starts - Variable in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
This is a map from start key to regions with the same start key.
- startScan(AsyncClientScanner.OpenScannerResponse) - Method in class org.apache.hadoop.hbase.client.AsyncClientScanner
-
- startServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Start maintenance Threads, Server, Worker and lease checker threads.
- startServiceThreads() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- startStopLock - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if the byte array on the right is a prefix of the byte array on the left.
- startTime - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
-
- startTime - Variable in class org.apache.hadoop.hbase.client.MetricsConnection.CallStats
-
- startTime - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
-
- startTime - Variable in class org.apache.hadoop.hbase.client.OnlineLogRecord
-
- startTime - Variable in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- startTime - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- startTime - Variable in class org.apache.hadoop.hbase.ipc.ServerCall
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALRecordReader
-
- startTime - Variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat.WALSplit
-
- startTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- startTime - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
-
- startTime - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- startTime - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController.ActiveOperation
-
- startTime - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- startTime - Variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- startTime - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- startTime - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- startTime - Variable in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- startTimestamp - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
- startTrackingTime - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker
-
- startTransition(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
-
Deprecated.
- startTransition(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
-
Deprecated.
- startTransition(MasterProcedureEnv, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
-
Deprecated.
- startup() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Initialize the environment
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup() - 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(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- 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
-
- startupOngoing - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- startWaitingForReplicaCalls(List<Action>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
-
Starts waiting to issue replica calls on a different thread; or issues them immediately.
- startWindow - Variable in class org.apache.hadoop.hbase.HealthCheckChore
-
- startWorkers() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Start the workers.
- startWriterThreads() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Called by the constructor to start the writer threads.
- startWriterThreads() - Method in class org.apache.hadoop.hbase.wal.OutputSink
-
Start the threads that will pump data from the entryBuffers to the output files.
- startWriting(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Starts writing into the block.
- stat - Variable in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
-
- STAT_THREAD_PERIOD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
- STAT_THREAD_PERIOD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- STAT_THREAD_PERIOD_SECONDS - Static variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- state - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- state - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl
-
- state - Variable in class org.apache.hadoop.hbase.client.TableState
-
- State() - Constructor for enum org.apache.hadoop.hbase.client.TableState.State
-
- state - Variable in class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
-
Current coprocessor state
- State() - Constructor for enum org.apache.hadoop.hbase.Coprocessor.State
-
- state - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- State() - Constructor for enum org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.State
-
- state - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Writer state.
- State() - Constructor for enum org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.State
-
- state - Variable in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- state - Variable in class org.apache.hadoop.hbase.master.assignment.RegionStateNode
-
A Region-in-Transition (RIT) moves through states.
- state - Variable in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
-
- state - Variable in class org.apache.hadoop.hbase.master.RegionState
-
- State() - Constructor for enum org.apache.hadoop.hbase.master.RegionState.State
-
- state - Variable in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
-
- State() - Constructor for enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
- state - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- state - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- state - Variable in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- State() - Constructor for enum org.apache.hadoop.hbase.procedure2.RootProcedureState.State
-
- state - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- State() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
-
- state - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
-
- State() - Constructor for enum org.apache.hadoop.hbase.ServerTask.State
-
- state - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- state - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- state - Variable in class org.apache.hadoop.hbase.SplitLogTask
-
Deprecated.
- STATE_BITS - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
-
- STATE_DESCRIPTION_ALIVE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- STATE_DESCRIPTION_NOT_LIVE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- STATE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The state column qualifier
- stateCount - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
-
- StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- stateFlow - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- StatelessUncompressor(CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.StatelessUncompressor
-
- stateLoaded(AssignmentManager, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- stateLoaded(AssignmentManager, RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
-
- StateMachineProcedure<TEnvironment,TState> - Class in org.apache.hadoop.hbase.procedure2
-
Procedure described by a series of steps.
- StateMachineProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- StateMachineProcedure.Flow - Enum in org.apache.hadoop.hbase.procedure2
-
- stateManager - Variable in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- states - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- STATES_EXPECTED_ON_ASSIGN - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- STATES_EXPECTED_ON_CLOSED - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- STATES_EXPECTED_ON_CLOSING - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- STATES_EXPECTED_ON_OPEN - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- STATES_EXPECTED_ON_UNASSIGN_OR_MOVE - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- StateSerializer(ProcedureProtos.Procedure.Builder) - Constructor for class org.apache.hadoop.hbase.procedure2.ProcedureUtil.StateSerializer
-
- stateTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- STATIC_BLOOM_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_BLOOM_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- staticBloomSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- staticIndexSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- StaticUserFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- StaticUserWebFilter - Class in org.apache.hadoop.hbase.http.lib
-
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who) so that the web UI
is usable for a secure cluster without authentication.
- StaticUserWebFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
-
- StaticUserWebFilter.StaticUserFilter - Class in org.apache.hadoop.hbase.http.lib
-
- StaticUserWebFilter.User - Class in org.apache.hadoop.hbase.http.lib
-
- statistics() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
-
- StatisticsThread(BucketCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.StatisticsThread
-
- StatisticsThread(LruAdaptiveBlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.StatisticsThread
-
- StatisticsThread(LruBlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.LruBlockCache.StatisticsThread
-
- StatisticsThread() - Constructor for class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool.StatisticsThread
-
- StatisticTrackable - Interface in org.apache.hadoop.hbase.client
-
Parent interface for an object to get updates about per-region statistics.
- stats - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
-
- stats - Variable in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- stats - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- stats - Variable in class org.apache.hadoop.hbase.client.Result
-
- stats - Variable in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- stats - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Cache statistics
- stats - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache statistics
- stats - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- STATS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.Options
-
- STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.BloomFilterUtil
-
Record separator for the Bloom filter statistics human-readable string
- statsPeriodInSecond - Variable in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- statsThreadPeriod - Variable in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- statsThreadPool - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- statThreadPeriod - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Statistics thread
- statThreadPeriod - Static variable in class org.apache.hadoop.hbase.regionserver.ChunkCreator.MemStoreChunkPool
-
Statistics thread
- statTimestamp - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
-
- Status() - Constructor for enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
- status - Variable in class org.apache.hadoop.hbase.HealthReport
-
- status - Variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- status - Variable in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
-
- status - Variable in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
-
- status - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- status - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
Deprecated.
- status - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- status - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl.StatusJournalEntryImpl
-
- Status() - Constructor for enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
- status - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder.ServerTaskImpl
-
- status - Variable in class org.apache.hadoop.hbase.ServerTaskBuilder
-
- status - Variable in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- status - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- status - Variable in class org.apache.hadoop.hbase.wal.OutputSink
-
- STATUS_LISTENER_CLASS - Static variable in class org.apache.hadoop.hbase.client.ClusterStatusListener
-
The implementation class to use to read the status.
- STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
IP to use for the multicast status messages between the master and the clients.
- STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for receiving multicast.
- STATUS_MULTICAST_NI_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The network interface name to use for the multicast messages.
- STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
The port to use for the multicast messages.
- STATUS_MULTICAST_PUBLISHER_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for sending multicast.
- STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The minimum time between two status messages, in milliseconds.
- STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Setting to activate, or not, the publication of the status by the master.
- STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The implementation class used to publish the status.
- StatusJournalEntryImpl(String, long) - Constructor for class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl.StatusJournalEntryImpl
-
- statusMsg - Variable in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
- statusTask - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- statusTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl.StatusJournalEntryImpl
-
- statusTime - Variable in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
-
- StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.CanaryTool.StdOutSink
-
- stealFromQueue - Variable in class org.apache.hadoop.hbase.util.StealJobQueue
-
- StealJobQueue<T> - Class in org.apache.hadoop.hbase.util
-
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
- StealJobQueue(Comparator<? super T>) - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
-
- StealJobQueue(int, int, Comparator<? super T>) - Constructor for class org.apache.hadoop.hbase.util.StealJobQueue
-
- step - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.SaslNegotiateHandler
-
- step - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- StepDirection() - Constructor for enum org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner.StepDirection
-
- stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
Removes the leader znode, if it is currently claimed by this instance.
- stepOne() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Corresponds to step 1 of the original algorithm.
- SteppingSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
- SteppingSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
-
- STEPS_PER_REGION_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stepsPerRegion - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stepThree() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Corresponds to step 3 of the original algorithm.
- stepTwo() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Corresponds to step 2 of the original algorithm.
- stochasticCosts - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancerSourceImpl
-
- 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
-
The constructor that pass a MetricsStochasticBalancer to BaseLoadBalancer to replace its
default MetricsBalancer
- StochasticLoadBalancer(MetricsStochasticBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- StochasticLoadBalancer.GeneratorType - Enum in org.apache.hadoop.hbase.master.balancer
-
- stochasticSource - Variable in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
-
Use the stochastic source instead of the default source.
- stop() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
-
- 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(String) - Method in class org.apache.hadoop.hbase.client.CatalogReplicaLoadBalanceSimpleSelector
-
- stop() - Method in class org.apache.hadoop.hbase.client.example.HttpProxyExample
-
- stop() - Method in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ExampleRegionObserverWithMetrics
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RefreshHFilesEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- stop() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- stop() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
stop the server
- stop() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.NettyRpcServer
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Stops serving new requests.
- stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
-
Deprecated.
Stops the service.
- stop(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.assignment.AssignmentManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- 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.MasterWalManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
-
- stop() - Method in class org.apache.hadoop.hbase.master.RegionServerTracker
-
- stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Stop the ServerManager.
- stop - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- 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.SnapshotManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Deprecated.
- stop(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- stop() - Method in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- stop() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
-
Gracefully shutdown the thread pool.
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Close this and all running tasks
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Close this and all running procedure tasks
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- stop() - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
-
- stop() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- stop() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
-
Stop the scheduler
- stop() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.NoopProcedureStore
-
- stop(boolean) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Stop/Close the procedure store
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.region.RegionProcedureStore
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- stop() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
-
- stop() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stop(String, boolean, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Stops the regionserver.
- stop() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
---------------------------------------------------------------------- The request to cancel
the compaction asynchronous task The compaction may still happen if the request was sent too
late Non-blocking request
- stop() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.ShutdownHook.DoNothingStoppable
-
- stop - Variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook.ShutdownHookThread
-
- stop() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
Abruptly shutdown the thread pool.
- 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
-
Deprecated.
stop the SplitLogWorker thread
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- stop() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
-
- stop() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
If the service is starting or running, this initiates service shutdown and returns immediately.
- stop() - Method in class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- stop() - Method in class org.apache.hadoop.hbase.rest.RESTServer
-
- stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- stop(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- stop(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
- 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.VisibilityReplication
-
- stop() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
-
Stop this service.
- stop() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the whole mini cluster, including zookeeper cluster, dfs cluster and hbase cluster.
- stop() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- stop() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- stop() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- stop() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- stop(long) - Method in class org.apache.hadoop.hbase.util.MovingAverage
-
Mark end time of an execution, and return its interval.
- stop() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
- stop() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
-
Stops the clearing of JMX metrics and restarting the Hadoop metrics system.
- stop() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
-
- stop() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
-
- STOP_TIMEOUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Time to wait for server to stop gracefully
- stopAssignmentThread() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
- stopBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
-
- stopBold() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- stopBold() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- stopChaosAgent - Static variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
-
- stopChores() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopCompaction() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
The request to cancel the compaction asynchronous task (caused by in-memory flush) The
compaction may still happen if the request was sent too late Non-blocking request
- stopConnectorServer() - Method in class org.apache.hadoop.hbase.JMXListener
-
- stopHBaseCluster() - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the hbase cluster.
- stopHBaseCluster() - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- stopHFileDeleteThreads() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Stop threads for hfile deletion
- stopHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
-
- stopHighlight() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
-
- stopHighlight() - Method in interface org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
-
- stopIdleScan() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
-
Deprecated.
- stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the current HBase master only.
- stopMaster() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Shuts down the current HBase master only.
- stopMaster() - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- stopMaster() - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- stopMaster(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the given master.
- stopMaster(ServerName) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- stopMaster() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- Stoppable - Interface in org.apache.hadoop.hbase
-
Implementers are Stoppable.
- StoppableThread - Class in org.apache.hadoop.hbase.procedure2
-
- StoppableThread(ThreadGroup, String) - Constructor for class org.apache.hadoop.hbase.procedure2.StoppableThread
-
- stopped - Variable in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
-
- stopped - Variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- stopped - Variable in class org.apache.hadoop.hbase.client.RegistryEndpointsRefresher
-
- stopped - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- stopped - Variable in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
-
- stopped - Variable in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- stopped - Variable in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- stopped - Variable in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerManager
-
- stopped - Variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- stopped - Variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- stopped - Variable in class org.apache.hadoop.hbase.metrics.impl.GlobalMetricRegistriesAdapter
-
- stopped - Variable in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- stopped - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
-
- stopped - Variable in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- stopped - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stopped - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
- stopped - Variable in class org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
-
- stopped - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
- stopped - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
-
- stopped - Variable in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- stopped - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.LeaderElector
-
- stopped - Variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
Flag for stopping the server
- stopped - Variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
-
- stopped - Static variable in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
-
- StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
-
- StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- stopper - Variable in class org.apache.hadoop.hbase.ScheduledChore
-
A means by which a ScheduledChore can be stopped.
- stopper - Variable in class org.apache.hadoop.hbase.util.Sleeper
-
- stopping - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stopPrefetch(AdvancedScanResultConsumer.ScanController) - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
-
- stopProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopProcessingTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Deprecated.
called when Coordination should stop processing tasks and exit
- stopProcessingTasks() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- stopRegionServer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Stop the designated regionserver.
- stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Stop the designated regionserver.
- stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- stopRegionServer(ServerName) - Method in interface org.apache.hadoop.hbase.testing.TestingHBaseCluster
-
Stop the given region server.
- stopRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.testing.TestingHBaseClusterImpl
-
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- stopReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplayingFromWAL() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplayingFromWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
This message intends to inform the MemStore that the replaying edits from WAL are done
- stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
-
- 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.LeaseManager
-
- stopRow - Variable in class org.apache.hadoop.hbase.client.Scan
-
- stopRow - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- stopRow - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- stopRow - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- stopRow - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- stopRow - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- stopRowInclusive - Variable in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.BasicRowRange
-
- stopRowKey - Variable in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- stopRunning() - Method in class org.apache.hadoop.hbase.ipc.RpcHandler
-
- stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Stop the region server.
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Wait on all threads to finish.
- stopSkippingKVsIfNextRow - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- stopSkippingKVsIfNextRow - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- stopSkippingKVsRow - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
-
- stopTask() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Deprecated.
If the worker is doing a task i.e.
- stopThreads - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
-
- stopUsingCurrentWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- stopWorker() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
-
- stopWriterThreads() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Only used in test n
- storage - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
- storage - Variable in class org.apache.hadoop.hbase.replication.regionserver.SerialReplicationChecker
-
- STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- STORAGE_POLICY_BYTES - Static variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
-
- STORAGE_POLICY_PREFIX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Date Tiered Compaction tmp dir prefix name if use storage policy
- STORAGE_POLICY_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- STORAGE_POLICY_PROPERTY_CF_PREFIX - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- StorageClusterStatusModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of the status of a storage cluster:
- StorageClusterStatusModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Default constructor
- StorageClusterStatusModel.Node - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region server.
- StorageClusterStatusModel.Node.Region - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region hosted on a region server.
- StorageClusterStatusResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
Constructor n
- StorageClusterVersionModel - Class in org.apache.hadoop.hbase.rest.model
-
Simple representation of the version of the storage cluster
- StorageClusterVersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- StorageClusterVersionResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
Constructor n
- store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- store - Variable in class org.apache.hadoop.hbase.procedure2.CompletedProcedureCleaner
-
- store - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- store - Variable in class org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionRunner
-
- 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.StoreFlusher
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- STORE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_ENGINE_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
The name of the configuration parameter that specifies the class of a store engine that is used
to manage and compact HBase store files.
- STORE_FILE_READER_NO_READAHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- STORE_FILE_REF_COUNT_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- STORE_REF_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_REF_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_SERVICES - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
- STORE_WAL_SYNC_STATS_COUNT - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- storeConfigInfo - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- 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.
- storeContext - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- StoreContext - Class in org.apache.hadoop.hbase.regionserver
-
This carries the immutable information and references on some of the meta data about the HStore.
- StoreContext(StoreContext.Builder) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreContext
-
- StoreContext.Builder - Class in org.apache.hadoop.hbase.regionserver
-
- storeCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- storeCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- storeCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- storeEngine - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- StoreEngine<SF extends 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
-
- StoreEngine.IOExceptionRunnable - Interface in org.apache.hadoop.hbase.regionserver
-
- StoreFile - Interface in org.apache.hadoop.hbase.regionserver
-
An interface to describe a store data file.
- storeFile(TRegion, TFamily, StoreFileInfo) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor
-
- storeFile(HRegionFileSystem, Path, StoreFileInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1.ManifestBuilder
-
- storeFile(SnapshotProtos.SnapshotRegionManifest.Builder, SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder, StoreFileInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2.ManifestBuilder
-
- storeFile(RegionInfo, 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_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_SIZE_COST_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StoreFileCostFunction
-
- STOREFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- storeFileComparator - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
- StoreFileComparators - Class in org.apache.hadoop.hbase.regionserver
-
Useful comparators for comparing store files.
- StoreFileComparators() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileComparators
-
- StoreFileComparators.GetBulkTime - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFileComparators.GetFileSize - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFileComparators.GetMaxTimestamp - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFileComparators.GetPathName - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFileCostFunction - Class in org.apache.hadoop.hbase.master.balancer
-
Compute the cost of total open storefiles size.
- StoreFileCostFunction(Configuration) - Constructor for class org.apache.hadoop.hbase.master.balancer.StoreFileCostFunction
-
- storeFileCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- storeFileCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- storeFileCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- storefileIndexSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- storefileIndexSizeKB - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- storefileIndexSizeKB - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- StoreFileInfo - Class in org.apache.hadoop.hbase.regionserver
-
Describe a StoreFile (hfile, reference, link)
- StoreFileInfo(Configuration, FileSystem, Path, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- StoreFileInfo(Configuration, FileSystem, FileStatus, Path, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- StoreFileInfo(Configuration, FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- StoreFileInfo(Configuration, FileSystem, FileStatus, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- StoreFileInfo(Configuration, FileSystem, FileStatus, Reference) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- StoreFileInfo(Configuration, FileSystem, FileStatus, Reference, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink and a Reference
- StoreFileListFile - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
To fully avoid listing, here we use two files for tracking.
- StoreFileListFile(StoreContext) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFile
-
- 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.
- StoreFileReader - Class in org.apache.hadoop.hbase.regionserver
-
Reader for a StoreFile.
- StoreFileReader(HFile.Reader, AtomicInteger, ReaderContext, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- StoreFileReader(ReaderContext, HFileInfo, CacheConfig, AtomicInteger, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
- StoreFileReader() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileReader
-
ONLY USE DEFAULT CONSTRUCTOR FOR UNIT TESTS
- storeFileRefCountThreshold - Variable in class org.apache.hadoop.hbase.master.RegionsRecoveryChore
-
- StoreFileReference(String) - Constructor for class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
-
- storefileRefresher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- StorefileRefresherChore - Class in org.apache.hadoop.hbase.regionserver
-
A chore for refreshing the store files for secondary regions hosted in the region server.
- StorefileRefresherChore(int, boolean, HRegionServer, Stoppable) - Constructor for class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- storefiles - Variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
-
List of store files inside this store.
- storefiles - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.FileBasedStoreFileTracker
-
- storefiles - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- storefiles - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
-
KeyValueScanner adaptor over the Reader.
- StoreFileScanner(StoreFileReader, HFileScanner, boolean, boolean, long, long, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- storeFileSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- storeFileSize - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- storeFileSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
-
- storeFileSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- storeFileSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl.MetricsTableValues
-
- storefileSizeMB - Variable in class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
-
- storefileSizeMB - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- storefileSizeMB - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- StoreFileSplitter(HRegionFileSystem, byte[], HStoreFile) - Constructor for class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure.StoreFileSplitter
-
Constructor that takes what it needs to split
- storeFileTracker - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- StoreFileTracker - Interface in org.apache.hadoop.hbase.regionserver.storefiletracker
-
An interface to define how we track the store files for a give store.
- StoreFileTrackerBase - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Base class for all store file tracker.
- StoreFileTrackerBase(Configuration, boolean, StoreContext) - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
-
- StoreFileTrackerFactory - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Factory method for creating store file tracker.
- StoreFileTrackerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
-
- StoreFileTrackerFactory.Trackers - Enum in org.apache.hadoop.hbase.regionserver.storefiletracker
-
Maps between configuration names for trackers and implementation classes.
- StoreFileTrackerState() - Constructor for enum org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure.StoreFileTrackerState
-
- StoreFileTrackerValidationUtils - Class in org.apache.hadoop.hbase.regionserver.storefiletracker
-
- StoreFileTrackerValidationUtils() - Constructor for class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
- StoreFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
A StoreFile writer.
- StoreFileWriter(FileSystem, Path, Configuration, CacheConfig, BloomType, long, InetSocketAddress[], HFileContext, boolean, Supplier<Collection<HStoreFile>>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileWriter
-
Creates an HFile.Writer that also write helpful meta data.
- StoreFileWriter.Builder - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFileWriterCreationTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.HStore.StoreFileWriterCreationTracker
-
- storeFileWriterCreationTrackerFactory - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- storeFileWriterCreationTrackers - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- storeFlushableSize - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- StoreFlushContext - Interface in org.apache.hadoop.hbase.regionserver
-
A package protected interface for a store flushing.
- storeFlushCtxs - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
-
- storeFlushedSequenceIdsByRegion - Variable in class org.apache.hadoop.hbase.master.ServerManager
-
The last flushed sequence id for a store in a region.
- storeFlusher - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- StoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Store flusher interface.
- StoreFlusher(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFlusher
-
- StoreFlusherImpl(long, FlushLifeCycleTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
-
- storeHeap - Variable in class org.apache.hadoop.hbase.regionserver.RegionScannerImpl
-
- storeHotnessProtector - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- StoreHotnessProtector - Class in org.apache.hadoop.hbase.regionserver.throttle
-
StoreHotnessProtector is designed to help limit the concurrency of puts with dense columns, it
does best-effort to avoid exhausting all RS's handlers.
- StoreHotnessProtector(Region, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
-
- storeInDispatchedQueue() - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
-
- storeInDispatchedQueue() - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteProcedure
-
Whether store this remote procedure in dispatched queue only OpenRegionProcedure and
CloseRegionProcedure return false since they are not fully controlled by dispatcher
- storeLimit - Variable in class org.apache.hadoop.hbase.client.Get
-
- storeLimit - Variable in class org.apache.hadoop.hbase.client.Scan
-
- storeLimit - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- storeLock - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- storeName - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
-
- storeOffset - Variable in class org.apache.hadoop.hbase.client.Get
-
- storeOffset - Variable in class org.apache.hadoop.hbase.client.Scan
-
- storeOffset - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- storeRefCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- storeRefCount - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- storeRefCount - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- stores - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- stores - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- stores - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactionRequest
-
- StoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the Store.
- StoreScanner(HStore, Scan, ScanInfo, int, long, boolean, ScanType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
An internal constructor.
- StoreScanner(HStore, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- StoreScanner(HStore, ScanInfo, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for store file compaction and memstore compaction.
- StoreScanner(HStore, ScanInfo, List<? extends KeyValueScanner>, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for compactions that drop deletes from a limited range of rows.
- StoreScanner(HStore, ScanInfo, List<? extends KeyValueScanner>, ScanType, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreScanner(ScanInfo, ScanType, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreScanner(Scan, ScanInfo, NavigableSet<byte[]>, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreScanner(Scan, ScanInfo, NavigableSet<byte[]>, List<? extends KeyValueScanner>, ScanType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreScanner(ScanInfo, int, ScanType, List<? extends KeyValueScanner>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- STORESCANNER_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- STORESCANNER_PREAD_MAX_BYTES - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
If the read type is Scan.ReadType.DEFAULT, we will start with pread, and if the kvs we scanned
reaches this limit, we will reopen the scanner with stream.
- storeSegments - Variable in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- storeSequenceIds - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder.RegionMetricsImpl
-
- storeSequenceIds - Variable in class org.apache.hadoop.hbase.RegionMetricsBuilder
-
- storesFirstKey - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- storeSize - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- storesLastKey - Variable in class org.apache.hadoop.hbase.util.HBaseFsck.RegionBoundariesInformation
-
Deprecated.
- storesToCompact - Variable in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
-
- StoreToFile(FileSystem) - Constructor for class org.apache.hadoop.hbase.backup.HFileArchiver.StoreToFile
-
- storeTracker - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- storeUncompressedSizeMB - Variable in class org.apache.hadoop.hbase.ServerLoad
-
Deprecated.
- 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
-
- Strategies(Class<? extends RegionGroupingProvider.RegionGroupingStrategy>) - Constructor for enum org.apache.hadoop.hbase.wal.RegionGroupingProvider.Strategies
-
- strategy - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- strategy - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
-
- Strategy() - Constructor for enum org.apache.hadoop.hbase.security.access.AccessControlFilter.Strategy
-
- strategy - Variable in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
-
- stream - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Two stream handles, one with and one without FS-level checksum.
- stream - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
Deprecated.
- stream - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- stream - Variable in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
- stream - Variable in class org.apache.hadoop.hbase.rest.client.Response
-
- StreamLacksCapabilityException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException
-
- StreamLacksCapabilityException(String) - Constructor for exception org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException
-
- streamLock - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
- streamNoFsChecksum - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- streamNoFsChecksumFirstCreateLock - Variable in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- streamSlowMonitor - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- StreamSlowMonitor - Class in org.apache.hadoop.hbase.io.asyncfs.monitor
-
Class for monitor the wal file flush performance.
- StreamSlowMonitor(Configuration, String, ExcludeDatanodeManager) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
-
- streamSlowMonitor - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- StreamSlowMonitor.PacketAckData - Class in org.apache.hadoop.hbase.io.asyncfs.monitor
-
- streamSlowMonitors - Variable in class org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
-
- streamUnsupported - Variable in class org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
-
- StreamUtils - Class in org.apache.hadoop.hbase.io.util
-
- StreamUtils() - Constructor for class org.apache.hadoop.hbase.io.util.StreamUtils
-
- streamWrapper - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
The file system stream of the underlying
HFile
that does or doesn't do checksum
validations in the filesystem
- STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
String overhead
- STRING_VIS_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- stringify(Class<?>[]) - Static method in class org.apache.hadoop.hbase.util.Classes
-
- stringifyFilter(Filter) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- stringIsNotEmpty(String) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- Strings - Class in org.apache.hadoop.hbase.util
-
Utility for Strings.
- Strings() - Constructor for class org.apache.hadoop.hbase.util.Strings
-
- StringUtils - Class in org.apache.hadoop.hbase.procedure2.util
-
- StringUtils() - Constructor for class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- 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.
- StripeCompaction() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreEngine.StripeCompaction
-
- 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.BoundaryStripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Request for stripe compactor that will cause it to split the source files into several separate
files at the provided boundaries.
- StripeCompactionPolicy.SplitStripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Request for stripe compactor that will cause it to split the source files into several separate
files into based on key-value count, as well as file count limit.
- StripeCompactionPolicy.StripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Stripe compaction request wrapper.
- StripeCompactionPolicy.StripeInformationProvider - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
The information about stripes that the policy needs to do its stuff
- StripeCompactionRequest(CompactionRequestImpl) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- StripeCompactionScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
-
Query matcher for stripe compaction if range drop deletes is used.
- StripeCompactionScanQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
-
- StripeCompactionScanQueryMatcher.DropDeletesInOutput - Enum in org.apache.hadoop.hbase.regionserver.querymatcher
-
- stripeCompactMaxFiles - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- stripeCompactMinFiles - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- StripeCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This is the placeholder for stripe compactor.
- StripeCompactor(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- StripeCompactor.StripeInternalScannerFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- stripeEndRows - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- stripeEndRows - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
-
The end rows of each stripe.
- stripeFiles - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.CompactionOrFlushMergeCopy
-
- stripeFiles - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
-
Files by stripe.
- StripeFlushRequest(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- StripeInternalScannerFactory(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor.StripeInternalScannerFactory
-
- StripeMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
Base class for cell sink that separates the provided cells into multiple files for stripe
compaction.
- StripeMultiFileWriter(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- StripeMultiFileWriter.BoundaryMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on fixed row-key boundaries.
- StripeMultiFileWriter.SizeMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on target cell number per file and file count.
- stripePolicy - Variable in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- stripeRequest - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine.StripeCompaction
-
- stripes - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- 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
-
- StripeStoreEngine.StripeCompaction - Class in org.apache.hadoop.hbase.regionserver
-
Represents one instance of stripe compaction, with the necessary context and flow.
- StripeStoreFileManager - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFileManager.
- StripeStoreFileManager(CellComparator, Configuration, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- StripeStoreFileManager.CompactionOrFlushMergeCopy - Class in org.apache.hadoop.hbase.regionserver
-
Non-static helper class for merging compaction or flush results.
- StripeStoreFileManager.KeyBeforeConcatenatedLists - Class in org.apache.hadoop.hbase.regionserver
-
An extension of ConcatenatedLists that has several peculiar properties.
- StripeStoreFileManager.KeyBeforeConcatenatedLists.Iterator - Class in org.apache.hadoop.hbase.regionserver
-
- StripeStoreFileManager.State - Class in org.apache.hadoop.hbase.regionserver
-
The state class.
- StripeStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFlusher.
- StripeStoreFlusher(Configuration, HStore, StripeCompactionPolicy, StripeStoreFileManager) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- StripeStoreFlusher.BoundaryStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on boundaries.
- StripeStoreFlusher.SizeStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on size.
- StripeStoreFlusher.StripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper that writes a non-striped file.
- stripMaster(List<ServerName>) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Exclude master from list of RSs to move regions to
- stripServer(List<ServerName>, String, int) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
Remove the servername whose hostname and port portion matches from the passed array of servers.
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
-
- strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
n * user or file input for row
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- Struct - Class in org.apache.hadoop.hbase.types
-
Struct
is a simple
DataType
for implementing "compound rowkey" and "compound
qualifier" schema design strategies.
- Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
-
Create a new Struct
instance defined as the sequence of HDataType
s in
memberTypes
.
- StructBuilder - Class in org.apache.hadoop.hbase.types
-
A helper for building
Struct
instances.
- StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
-
Create an empty StructBuilder
.
- StructIterator - Class in org.apache.hadoop.hbase.types
-
An
Iterator
over encoded
Struct
members.
- StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
-
Construct StructIterator
over the values encoded in src
using the specified
types
definition.
- sttyCooked() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- sttyRaw() - Method in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
-
- stub - Variable in class org.apache.hadoop.hbase.client.AsyncClientScanner.OpenScannerResponse
-
- stub - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- stub(ClientProtos.ClientService.Interface) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder
-
- stub - Variable in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
-
- stub - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation.MasterServiceState
-
- stub - Variable in class org.apache.hadoop.hbase.client.locking.EntityLock
-
- stub - Variable in class org.apache.hadoop.hbase.client.locking.LockServiceClient
-
- stub - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- stub - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- stub - Variable in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- stub - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
-
- stubMaker - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CoprocessorServiceBuilderImpl
-
- stubs - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
-
- stuckThreshold - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
-
- subcontext - Variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.MapRunner
-
- subFiltersIncludedCell - Variable in class org.apache.hadoop.hbase.filter.FilterListBase
-
For each sub-filter in filter list, we save a boolean flag to indicate that whether the return
code of filterCell(c) for sub-filter is INCLUDE* (INCLUDE, INCLUDE_AND_NEXT_COL,
INCLUDE_AND_SEEK_NEXT_ROW) case.
- subList(int, int) - Method in class org.apache.hadoop.hbase.util.SortedList
-
- subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- subMap(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- subMap(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- subMap(K, K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- subMap(K, boolean, K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- SubMapRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- SubMapRecordWriter() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordWriter
-
- SubMapStatusReporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapStatusReporter
-
- submit(AsyncProcessTask<CResult>) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
The submitted task may be not accomplished at all if there are too many running tasks or other
limits.
- submit(AsyncProcessTask<CResult>, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
Extract from the rows list what we can submit.
- submit(RetryingCallable<V>, int, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.Executor
-
Submit the event to the queue for handling.
- submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- submit(Callable<V>) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- submitAll(AsyncProcessTask) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
Submit immediately the list of rows, whatever the server status.
- submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv>, Procedure<MasterProcedureEnv>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- submitBatchedMultiOrSequential(ZKWatcher, boolean, List<ZKUtil.ZKUtilOp>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Chunks the provided ops
when their approximate size exceeds the the configured limit.
- submitChildrenProcedures(Procedure<TEnvironment>[]) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- submitMergePlan(MergeNormalizationPlan) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- submitMultiActions(AsyncProcessTask, List<Action>, long, List<Exception>, List<Integer>, Map<ServerName, MultiAction>) - Method in class org.apache.hadoop.hbase.client.AsyncProcess
-
- submitPlans(List<NormalizationPlan>) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- submitProcedure(Procedure<MasterProcedureEnv>, NonceKey) - Method in class org.apache.hadoop.hbase.master.ClusterSchemaServiceImpl
-
- submitProcedure(LockProcedure, NonceKey) - Method in class org.apache.hadoop.hbase.master.locking.LockManager
-
- submitProcedure(Procedure<MasterProcedureEnv>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil.NonceProcedureRunnable
-
- submitProcedure(MasterProcedureUtil.NonceProcedureRunnable) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
Helper used to deal with submitting procs with nonce.
- submitProcedure(ProcedureExecutor<MasterProcedureEnv>, Procedure<MasterProcedureEnv>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- submitProcedure(Procedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Submit an procedure to kick off its dependent subprocedures.
- submitProcedure(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a new root-procedure to the executor.
- submitProcedure(Procedure<TEnvironment>, NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a new root-procedure to the executor.
- submitProcedures(Procedure<TEnvironment>[]) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a set of new root-procedure to the executor.
- submitRegionMovesWhileUnloading(ServerName, List<ServerName>, List<RegionInfo>, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.util.RegionMover
-
- submitRegionProcedure(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Will ignore the open/close region procedures which already submitted or executed.
- submitServerCrash(ServerName, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
-
Usually run by the Master in reaction to server crash during normal processing.
- submitSplitPlan(SplitNormalizationPlan) - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerWorker
-
- submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Submit an subprocedure for execution.
- submitTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Deprecated.
- submitTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- submitTask(String, int, int) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Submit a log split task to executor service
- submitTask(Callable<Void>) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
-
Submit a task to the pool.
- submitTask(Runnable) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- submitTask(Runnable, long, TimeUnit) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
-
- submitTask(Callable<Void>) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
-
Submit a task to the pool.
- SUBMITTED_COUNT - Static variable in class org.apache.hadoop.hbase.metrics.OperationMetrics
-
- submittedCounter - Variable in class org.apache.hadoop.hbase.metrics.OperationMetrics
-
- submittedRegionProcedures - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Used to cache the open/close region procedures which already submitted.
- submittedRows - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask.Builder
-
- submittedRows - Variable in class org.apache.hadoop.hbase.client.AsyncProcessTask
-
- SubmittedRows() - Constructor for enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
-
- SubmittedSizeChecker(long) - Constructor for class org.apache.hadoop.hbase.client.SimpleRequestController.SubmittedSizeChecker
-
- submittedTime - Variable in class org.apache.hadoop.hbase.procedure2.Procedure
-
- 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.
- SubprocedureFactory - Interface in org.apache.hadoop.hbase.procedure
-
- SubprocedureImpl(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- subProcList - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- subprocs - Variable in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
- subprocs - Variable in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- subProcs - Variable in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree.Entry
-
- subprocStack - Variable in class org.apache.hadoop.hbase.procedure2.RootProcedureState
-
- subset(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Returns a subset of the configuration properties, matching the given key prefix.
- subSet(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- subSet(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
-
- subSet(K, boolean, K, boolean) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- subSet(K, K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
-
- substr - Variable in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- SubstringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a
given column.
- SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Constructor
- substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SubstringType byte array
- SUBSYSTEM_KEY - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- subtract(JvmPauseMonitor.GcTimes) - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor.GcTimes
-
- sucAppend - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- succ - Variable in class org.apache.hadoop.hbase.master.procedure.ServerRemoteProcedure
-
- success - Variable in class org.apache.hadoop.hbase.client.CheckAndMutateResult
-
- success() - Static method in class org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler.BufferCallEvent
-
- SUCCESS - Static variable in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
Singleton for successful operations.
- SUCCESS_EVENT - Static variable in class org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler
-
- successes - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerTask
-
- successful - Variable in class org.apache.hadoop.hbase.ipc.CallRunner
-
- SUCCESSFUL_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_LOG_ROLLS - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SUCCESSFUL_LOG_ROLLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SUCCESSFUL_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- successfulCoalescings - Variable in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- successfulLogRolls - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- sucDel - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- sucGet - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- sucIncrement - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- sucPut - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- sucScan - Variable in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- SUFFICIENT_MEMORY_LEVEL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- sufficientMemoryLevel - Variable in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
-
- suffix(String, String) - Static method in class org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
-
- sum() - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
-
- sum - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
-
Deprecated.
- sum(long[]) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- sum - Variable in class org.apache.hadoop.hbase.util.ByteBufferArray.BufferIterator
-
- sum(int) - Method in class org.apache.hadoop.hbase.util.WindowMovingAverage
-
- summarize() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.PrintingErrorReporter
-
Deprecated.
- summarize() - Method in interface org.apache.hadoop.hbase.util.HbckErrorReporter
-
Deprecated.
- Summary - Class in org.apache.hadoop.hbase.hbtop.screen.top
-
Represents the summary of the metrics.
- Summary(String, String, String, int, int, int, int, int, double, long) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- summary - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- summary - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
Deprecated.
- SUMMARY_ROW_NUM - Static variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- SUMMARY_START_ROW - Static variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
-
- summer - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
-
- sumMultiplier - Variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
sum of milliseconds between sequential next calls
- SUN_MGMT_DOMAIN - Static variable in class org.apache.hadoop.hbase.util.JSONMetricUtil
-
- superGroups - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
- SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
Configuration key for superusers
- Superusers - Class in org.apache.hadoop.hbase.security
-
Keeps lists of superusers and super groups loaded from HBase configuration, checks if certain
user is regarded as superuser.
- Superusers() - Constructor for class org.apache.hadoop.hbase.security.Superusers
-
- superUsers - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
- supplier - Variable in class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
-
- supplier - Variable in class org.apache.hadoop.hbase.master.http.jersey.MasterFeature
-
- SupplierFactoryAdapter<T> - Class in org.apache.hadoop.hbase.http.jersey
-
Use a
Supplier
of type
T
as a
Factory
that provides instances of
T
.
- SupplierFactoryAdapter(Supplier<T>) - Constructor for class org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
-
- supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
- supportsProtocolAuthentication() - Method in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider
-
- supportsProtocolAuthentication() - Method in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
-
- supportsProtocolAuthentication() - Method in class org.apache.hadoop.hbase.security.provider.GssSaslServerAuthenticationProvider
-
- supportsProtocolAuthentication() - Method in interface org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider
-
- supportsProtocolAuthentication() - Method in class org.apache.hadoop.hbase.security.provider.SimpleSaslServerAuthenticationProvider
-
- supportsProxyuser() - Method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- suppressHdfsShutdownHook(FileSystem) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- suspend() - Method in interface org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
-
Suspend the scan.
- suspend() - Method in class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl
-
- suspend(Configuration, LongConsumer) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
-
- suspend(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.SplitWALManager.SplitWorkerAssigner
-
- suspend() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
Mark the event as not ready.
- suspended - Variable in class org.apache.hadoop.hbase.master.locking.LockProcedure
-
- suspendedProcedures - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
- suspendIfNotReady(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureEvent
-
Returns true if event is not ready and adds procedure to suspended queue, else returns false.
- swap(VersionedSegmentsList, ImmutableSegment, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
Swaps the versioned list at the tail of the pipeline with a new segment.
- swapCompactedSegments(VersionedSegmentsList, ImmutableSegment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- swapPipelineWithNull(VersionedSegmentsList) - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
-
- SwapRegionsAction - Class in org.apache.hadoop.hbase.master.balancer
-
- SwapRegionsAction(int, int, int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.SwapRegionsAction
-
- swapSuffix(List<? extends Segment>, ImmutableSegment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- sweep(T) - Method in interface org.apache.hadoop.hbase.util.LossyCounting.LossyCountingListener
-
- sweep() - Method in class org.apache.hadoop.hbase.util.LossyCounting
-
sweep low frequency data
- SweepRunnable() - Constructor for class org.apache.hadoop.hbase.util.LossyCounting.SweepRunnable
-
- SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- switchBalancer(boolean, MasterRpcServices.BalanceSwitchMode) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Assigns balancer switch according to BalanceSwitchMode
- switchCompact(AdminProtos.AdminService.BlockingInterface, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- switchCompact(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- switchCompaction(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester
-
on/off compaction
- switchCompaction(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplit
-
- switched(WALEntryStream, Path) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
-
- switchedToADifferentReplica() - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
-
When a scanner switches in the middle of scanning (the 'next' call fails for example), the
upper layer
ClientScanner
needs to know
- switchExceedThrottleQuota(RpcController, MasterProtos.SwitchExceedThrottleQuotaRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- switchExceedThrottleQuota(RpcController, MasterProtos.SwitchExceedThrottleQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- switchExceedThrottleQuota(MasterProtos.SwitchExceedThrottleQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- switchExceedThrottleQuota(Connection, boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- switchFieldDisplay() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
-
- switchMapping - Variable in class org.apache.hadoop.hbase.master.RackManager
-
- switchMode(Mode, boolean, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- switchMode(Mode, Field, boolean, List<Field>, Boolean, List<RecordFilter>) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- switchMode(Mode) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Switch the rpc throttle enable state.
- switchRpcThrottle(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
-
Switch the rpc throttle enabled state.
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
-
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- switchRpcThrottle(RpcController, MasterProtos.SwitchRpcThrottleRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- switchRpcThrottle(RpcController, MasterProtos.SwitchRpcThrottleRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- switchRpcThrottle(MasterProtos.SwitchRpcThrottleRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
-
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.quotas.RpcThrottleStorage
-
Store the rpc throttle value.
- switchRpcThrottle(boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- SwitchRpcThrottleProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to switch rpc throttle
- SwitchRpcThrottleProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- SwitchRpcThrottleProcedure(RpcThrottleStorage, boolean, ServerName, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- SwitchRpcThrottleRemoteCallable - Class in org.apache.hadoop.hbase.replication.regionserver
-
The callable executed at RS side to switch rpc throttle state.
- SwitchRpcThrottleRemoteCallable() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.SwitchRpcThrottleRemoteCallable
-
- SwitchRpcThrottleRemoteProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to switch rpc throttle on region server
- SwitchRpcThrottleRemoteProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- SwitchRpcThrottleRemoteProcedure(ServerName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
-
- switchSnapshotCleanup(RpcController, MasterProtos.SetSnapshotCleanupRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
-
- switchSnapshotCleanup(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Turn on/off Snapshot Cleanup Chore
- switchSnapshotCleanup(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- switchSnapshotCleanup(RpcController, MasterProtos.SetSnapshotCleanupRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- switchSnapshotCleanup(boolean, boolean) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Turn on/off snapshot auto-cleanup based on TTL
- switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
-
- switchSortOrder() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
-
- SwitchStateTracker(ZKWatcher, String, Abortable) - Constructor for class org.apache.hadoop.hbase.master.SplitOrMergeTracker.SwitchStateTracker
-
- switchThrottleState(MasterProcedureEnv, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- switchZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
-
- 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 n
- sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileMmapIOEngine
-
Sync the data to file after writing n
- sync() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Sync the data to IOEngine after writing n
- sync(long, Durability) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Calls sync with the given transaction ID
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- sync(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
- sync(WALProvider.AsyncWriter) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
-
- sync(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- sync - Variable in class org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck
-
Either this syncFuture is set or entry is set, but not both.
- sync() - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- sync(long) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
-
- sync() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync what we have in the WAL.
- sync(long) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync the WAL if the txId was not already sync'd.
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- sync(long, boolean) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
-
- sync(boolean) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- SYNC_FUTURE_INVALIDATION_TIMEOUT_MINS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
- SYNC_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
- SYNC_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
-
- SYNC_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SYNC_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SYNC_TIMERANGE_TRACKER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for SyncTimeRangeTracker
- SYNC_WAIT_MSEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncCompleted(long, WALProvider.AsyncWriter, long, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- syncCond - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- SyncCoprocessorRpcChannel - Class in org.apache.hadoop.hbase.client
-
Base class which provides clients with an RPC connection to call coprocessor endpoint
Service
s.
- SyncCoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
-
- syncedEntries - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- syncedLength - Variable in class org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
-
- syncedLength - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- syncedPerSec - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- SYNCER_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- syncException - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncFailed(long, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- SyncFuture - Class in org.apache.hadoop.hbase.regionserver.wal
-
A Future on a filesystem sync call.
- SyncFuture() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
- syncFutureCache - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
-
A cache of sync futures reused by threads.
- SyncFutureCache - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SyncFutureCache(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
- syncFutureCache - Variable in class org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
-
- syncFutures - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
-
- syncFutures - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- syncFutures - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
- syncFuturesCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- synchronousBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- syncId - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncLatch - Variable in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
-
- syncLatch - Variable in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
-
- syncLatch - Variable in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleProcedure
-
- syncLoop() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- SyncMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
- syncMaxSlot - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- SyncMetrics() - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- syncMetricsQueue - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncOpLatency - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- syncOrTimeout(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
-
Forces a synchronization of this ZooKeeper client connection within a timeout.
- syncRange(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
Rescan the given range directly from the source and target tables.
- syncRowCells(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, byte[], SyncTable.SyncMapper.CellScanner, SyncTable.SyncMapper.CellScanner) - Method in class org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
-
Compare the cells for the given row from the source and target tables.
- SyncRunner(String, int) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
-
- syncRunnerIndex - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
Which syncrunner to use next.
- syncRunners - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
-
- syncSlots() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncSlots(FSDataOutputStream, ByteSlot[], int, int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- 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.CellScanner - Class in org.apache.hadoop.hbase.mapreduce
-
- SyncTable.SyncMapper.Counter - Enum in org.apache.hadoop.hbase.mapreduce
-
- syncThread - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- SyncTimeRangeTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- SyncTimeRangeTracker(TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- SyncTimeRangeTracker(long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
-
- syncWaitMs - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.SyncMetrics
-
Deprecated.
- syncWaitMsec - Variable in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
Deprecated.
- syncWaitTimeout - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- syncWaitTimeout - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
-
- SYS_TABLE_QUEUE_SIZE - Static variable in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
- SYSTABLE_PUT_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
-
- SYSTEM_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Default interval for System tables memstore flush
- SYSTEM_LABEL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SYSTEM_LABEL_ORDINAL - Static variable in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
System namespace name.
- SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- SYSTEM_TABLES_ON_MASTER - Static variable in interface org.apache.hadoop.hbase.master.LoadBalancer
-
- systemErrorFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
-
- SystemExitWhenAbortTimeout() - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer.SystemExitWhenAbortTimeout
-
- systemTable - Variable in class org.apache.hadoop.hbase.TableName
-
- SYSTEMTABLE_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SystemTableWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Skips WAL edits for all System tables including hbase:meta.
- SystemTableWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
-
- systemUser - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
- v - Variable in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap.Payload
-
- V1_PROCESSED_WILDCARD_MASK - Static variable in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- V2_PROCESSED_WILDCARD_MASK - Static variable in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseTimeToLiveFileCleaner
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveMasterLocalStoreHFileCleaner
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveMasterLocalStoreWALCleaner
-
- valiateFilename(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveProcedureWALCleaner
-
Deprecated.
- VALID_NAMESPACE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
-
- VALID_PORT_REGEX - Static variable in class org.apache.hadoop.hbase.util.Addressing
-
- VALID_TABLE_QUALIFIER_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
-
- VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.TableName
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Validate the file to see if it even belongs in the directory.
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- validate(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.ClientZKSyncer
-
Validate whether a znode path is watched by us
- validate(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.MasterAddressSyncer
-
- validate(String) - Method in class org.apache.hadoop.hbase.master.zksyncer.MetaLocationSyncer
-
- validate(Path) - Method in class org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
-
- validate(SnapshotProtos.SnapshotDescription, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Convert the passed snapshot description into a 'full' snapshot description based on default
parameters, if none have been supplied.
- validate() - Method in class org.apache.hadoop.hbase.TagBuilderImpl
-
- validate(ClassLoader, String, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- VALIDATE_CP_NAME - Static variable in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- VALIDATE_DBE_NAME - Static variable in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- VALIDATE_HFILE - Static variable in class org.apache.hadoop.hbase.tool.PreUpgradeValidator
-
- validateBlockAddition(Cacheable, Cacheable, BlockCacheKey) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
Validate that the existing and newBlock are the same without including the nextBlockMetadata,
if not, throw an exception.
- validateBlockType(HFileBlock, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
-
Compares the actual type of a block retrieved from cache or disk with its expected type and
throws an exception in case of a mismatch.
- validateCallerWithFilterUser(User, TablePermission, String) - Method in class org.apache.hadoop.hbase.security.access.AccessChecker
-
- validateCFAndCQ(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- validateChecksum(ByteBuff, String, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Validates that the data in the specified HFileBlock matches the checksum.
- validateChecksum(long, ByteBuff, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Generates the checksum for the header as well as the data and then validates it.
- validateClass(Procedure<?>) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureUtil
-
- validateClasses(ClassLoader, List<String>, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- validateClasses(ClassLoader, String[], List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- validateClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Verifies that the given key matches the expected format for a ZooKeeper cluster key.
- validateCompositeKey(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
-
- validateDBE() - Method in class org.apache.hadoop.hbase.tool.DataBlockEncodingValidator
-
Check DataBlockEncodings of column families are compatible.
- validateFamiliesInHFiles(Table, Deque<LoadIncrementalHFiles.LoadQueueItem>, boolean) - Method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Checks whether there is any invalid family name in HFiles to be bulk loaded.
- validateFields() - Method in class org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
-
- validateFilterUser(String, String, List<String>) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
-
- validateHFileContent(Configuration) - Method in class org.apache.hadoop.hbase.tool.HFileContentValidator
-
Check HFile contents are readable by HBase 2.
- validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- validateMobFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.HMobStore
-
Validates a mob file by opening and closing it.
- validatePath(Path, Path) - Static method in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
Validates a single whitelist path against the coprocessor path
- validatePreRestoreSnapshot(TableDescriptor, TableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
-
Makes sure restoring a snapshot does not break the current SFT setup follows
StoreUtils.createStoreConfiguration
- validateProcedureWALFilename(String) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureUtil
-
A Procedure WAL file name is of the format: pv-<wal-id>.log where wal-id is 20 digits.
- validateProtoArguments(QuotaProtos.SpaceQuota) - Static method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
Validates that the provided protobuf SpaceQuota has the necessary information to construct a
SpaceLimitSettings
.
- validatePut(Put, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- validatePut(Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
- validatePutsInRowMutations(RowMutations, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- validateQuotaTarget(QuotaSettings) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
Validates that settings being merged into this
is targeting the same "subject", e.g.
- validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.CommonFSUtils
-
Verifies root directory path is a valid URI with a scheme
- validateRSGroup(TableDescriptor, RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
-
- validateSFT() - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
-
- validateSizeLimit(long) - Method in class org.apache.hadoop.hbase.quotas.SpaceLimitSettings
-
- validateStoreFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Validates a store file by opening and closing it.
- validateStoreFileName(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Validate the store file name.
- validateSuffixList(LinkedList<ImmutableSegment>) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
- validateTableAndRegionCount(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- validateTables(ClassLoader, Admin, Pattern, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- validateTables(ClassLoader, Pattern, List<CoprocessorViolation>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
-
- validateTimedQuota(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
-
- validateTimedQuota(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.quotas.ThrottleSettings
-
- validateWALFilename(String) - Static method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
-
- validAuthChars - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- validProcs - Variable in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
-
- valLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.KeyValueStatsCollector
-
- value - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate.Builder
-
- value - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate
-
- value - Variable in class org.apache.hadoop.hbase.client.HTable.CheckAndMutateBuilderImpl
-
- value - Variable in class org.apache.hadoop.hbase.client.RawAsyncTableImpl.CheckAndMutateBuilderImpl
-
- value() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value of the first column in the Result.
- value - Variable in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- value - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- value - Variable in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- value - Variable in class org.apache.hadoop.hbase.hbtop.field.FieldValue
-
- value - Variable in class org.apache.hadoop.hbase.hbtop.RecordFilter
-
- value - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- value - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache.CachedBlockView
-
- value - Variable in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat.HFileRecordReader
-
A private cache of the key value so it doesn't need to be loaded twice from the scanner.
- value - Variable in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper.SubMapRecordReader
-
- value - Variable in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- value - Variable in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
-
- value - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- value - Variable in class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- value - Variable in class org.apache.hadoop.hbase.rest.model.CellModel
-
- value - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.ByteArrayComparableModel
-
- value - Variable in class org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel
-
- value - Variable in class org.apache.hadoop.hbase.Size
-
- value - Variable in class org.apache.hadoop.hbase.thrift2.client.ThriftTable.CheckAndMutateBuilderImpl
-
- value - Variable in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.COWEntry
-
- value - Variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- value - Variable in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- value() - Method in class org.apache.hadoop.metrics2.lib.MutableFastCounter
-
- value - Variable in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles.SampleItem
-
Value of the sampled item (e.g.
- VALUE_MASK - Static variable in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Deprecated.
- ValueAndTagRewriteByteBufferExtendedCell(ByteBufferExtendedCell, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell
-
- ValueAndTagRewriteCell(Cell, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.PrivateCellUtil.ValueAndTagRewriteCell
-
- valueBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- valueBuffer - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- valueCompressionType - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- valueCompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- ValueCompressor(Compression.Algorithm) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
-
- ValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on column value.
- ValueFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
- ValueFilter(CompareOperator, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
Constructor.
- valueFrom(Scan) - Static method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- valueFrom(Row) - Static method in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
-
- valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.CompressionState
-
- valueLength - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.backup.BackupType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.CatalogReplicaMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.Cell.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.CellBuilderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.chaos.ChaosService.ChaosServiceName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.chaos.ChaosService.ExecutorAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AbstractResponse.ResponseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.Retry
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.CompactionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.CompactType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Consistency
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.MasterSwitchType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.RegionLocateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.ScannerCallable.MoreResults
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.ServerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.SnapshotType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.TableState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.ClusterMetrics.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.CompareOperator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.MetaTableOps
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
-
Returns the enum constant of this type with the specified name.
- valueOf(ServerName) - Static method in class org.apache.hadoop.hbase.favored.StartcodeAgnosticServerName
-
- valueOf(String, long) - Static method in class org.apache.hadoop.hbase.favored.StartcodeAgnosticServerName
-
- valueOf(HostAndPort, long) - Static method in class org.apache.hadoop.hbase.favored.StartcodeAgnosticServerName
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.SatisfiesCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.field.FieldValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.RecordFilter.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.Color
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator.ParseState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.HealthChecker.HealthCheckerExitStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.log.LogLevel.Operations
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.ProfileServlet.Event
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.http.ProfileServlet.Output
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockCacheFactory.ExternalBlockCaches
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler.BufferCallAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.ipc.CallEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl.SourceStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterMapper.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.assignment.ServerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure.TransitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.BalanceAction.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.BalancerClusterState.LocalityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer.GeneratorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.cleaner.DirScanPool.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.MasterRpcServices.BalanceSwitchMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl.FactoryStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.normalizer.NormalizationPlan.PlanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.MetaProcedureInterface.MetaOperationType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface.PeerOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface.ServerOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.MetaRegionLocationCache.ZNodeOpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.MetaTableAccessor.QueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.metrics.BaseSourceImpl.DefaultMetricsSystemInitializer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskFilter.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.LockedResourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.LockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.Procedure.LockState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.RootProcedureState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.StateMachineProcedure.Flow
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker.DeleteState
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.quotas.ThrottlingException.Type
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl.DisplayCompactionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner.StepDirection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.FlushType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher.DropDeletesInOutput
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure.StoreFileTrackerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl.SourceHolder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper.WorkerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.ByteArrayComparableModel.ComparatorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.FilterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.AccessControlFilter.Strategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.AccessController.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Scope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Return the object represented by the code.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
Retrieve an instance of ServerName.
- valueOf(Address, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.ServerTask.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.Size.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns the enum constant of this type with the specified name.
- valueOf(String, String) - Static method in class org.apache.hadoop.hbase.TableName
-
- valueOf(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(String) - Static method in class org.apache.hadoop.hbase.TableName
-
Construct a TableName
- valueOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- valueOf(ByteBuffer, ByteBuffer) - Static method in class org.apache.hadoop.hbase.TableName
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl.FactoryStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.tool.CanaryTool.RegionTask.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.ReadType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.RpcSystem
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.PureJavaComparer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.UnsafeComparer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.DNS.ServerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.IdReadWriteLock.ReferenceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.Order
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String, PoolMap.PoolType) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String, PrettyPrinter.Unit) - Static method in class org.apache.hadoop.hbase.util.PrettyPrinter
-
Convert a human readable string to its value.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.wal.RegionGroupingProvider.Strategies
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.wal.WALFactory.Providers
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.metrics2.lib.MetricsExecutorImpl.ExecutorSingleton
-
Returns the enum constant of this type with the specified name.
- valueOffset - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
-
- valueOffset - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OnheapDecodedCell
-
- valueOffset - Variable in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.SeekerState
-
- valueOffset - Variable in class org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1.SeekerState
-
- ValueRewritingObserver - Class in org.apache.hadoop.hbase.coprocessor.example
-
This RegionObserver replaces the values of Puts from one value to another on compaction.
- ValueRewritingObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.example.ValueRewritingObserver
-
- values() - Static method in enum org.apache.hadoop.hbase.backup.BackupType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.CatalogReplicaMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.Cell.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.CellBuilderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.chaos.ChaosService.ChaosServiceName
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.chaos.ChaosService.ExecutorAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.AbstractResponse.ResponseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.Retry
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- values - Variable in class org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
-
- values() - Static method in enum org.apache.hadoop.hbase.client.CompactionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.CompactType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.Consistency
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.LogQueryFilter.Type
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.MasterSwitchType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.RegionLocateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.RequestController.ReturnCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.Scan.ReadType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.ScannerCallable.MoreResults
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.security.SecurityCapability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.ServerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.SnapshotType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
-
A map which holds the metadata information of the table.
- values() - Static method in enum org.apache.hadoop.hbase.client.TableState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.ClusterMetrics.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.CompareOperator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.coprocessor.MetaTableMetrics.MetaTableOps
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.ExecutorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.SatisfiesCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.field.Field
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.field.FieldValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.mode.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.hbtop.Record
-
- values() - Method in class org.apache.hadoop.hbase.hbtop.Record
-
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.RecordFilter.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.Color
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator.ParseState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.HealthChecker.HealthCheckerExitStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.http.log.LogLevel.Operations
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.http.ProfileServlet.Event
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.http.ProfileServlet.Output
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockCacheFactory.ExternalBlockCaches
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockPriority
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
-
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler.BufferCallAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.ipc.CallEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl.SourceStorage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.KeepDeletedCells
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapred.RowCounter.RowCounterMapper.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.CellCounter.CellCounterMapper.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.RowCounter.RowCounterMapper.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.assignment.ServerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure.TransitionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.balancer.BalanceAction.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.balancer.BalancerClusterState.LocalityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer.GeneratorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.cleaner.DirScanPool.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.MasterRpcServices.BalanceSwitchMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl.FactoryStorage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.normalizer.NormalizationPlan.PlanType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.procedure.MetaProcedureInterface.MetaOperationType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface.PeerOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.procedure.ServerProcedureInterface.ServerOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.procedure.TableProcedureInterface.TableOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.MetaRegionLocationCache.ZNodeOpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.MetaTableAccessor.QueryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.metrics.BaseSourceImpl.DefaultMetricsSystemInitializer
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.metrics.impl.RefCountingMap
-
- values() - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskFilter.TaskType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.LockedResourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.LockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.Procedure.LockState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.RootProcedureState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.StateMachineProcedure.Flow
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.ProcedureStoreTracker.DeleteState
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore.PushType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.QuotaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.ThrottleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.quotas.ThrottlingException.Type
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.BloomType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
-
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl.DisplayCompactionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner.StepDirection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.FlushType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher.DropDeletesInOutput
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.Region.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure.StoreFileTrackerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader.WALHdrResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl.SourceHolder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper.WorkerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.ByteArrayComparableModel.ComparatorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.rest.model.ScannerModel.FilterModel.FilterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.AccessControlFilter.Strategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.AccessController.OpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Scope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.SaslStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.ServerTask.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.Size.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.ImplType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl.FactoryStorage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.tool.CanaryTool.RegionTask.TaskType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.ReadType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.RpcSystem
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap
-
- values() - Static method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.PureJavaComparer
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.Bytes.LexicographicalComparerHolder.UnsafeComparer
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.DNS.ServerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.IdReadWriteLock.ReferenceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.Order
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- values() - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap.RoundRobinPool
-
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap.ThreadLocalPool
-
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- values() - Static method in enum org.apache.hadoop.hbase.util.PrettyPrinter.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.wal.RegionGroupingProvider.Strategies
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.wal.WALFactory.Providers
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.metrics2.lib.MetricsExecutorImpl.ExecutorSingleton
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesI - Variable in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- valueUpdater - Static variable in class org.apache.hadoop.hbase.util.Counter.Cell
-
Deprecated.
- VARIABLE_START - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
- verbose - Variable in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- verbose - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- verbose - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- Verifier() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- verifier - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- verifyBulkLoads - Variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- verifyCapacityAndClasses(long, String, String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- verifyChecksum - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.ExportMapper
-
- verifyChecksum - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- verifyChunkedSums(DataChecksum, ByteBuff, ByteBuff, String) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Like the hadoop's DataChecksum.verifyChunkedSums(ByteBuffer, ByteBuffer, String, long)
,
this method will also verify checksum of each chunk in data.
- verifyCoprocessors(ObserverContext<MasterCoprocessorEnvironment>, TableDescriptor) - Static method in class org.apache.hadoop.hbase.security.access.CoprocessorWhitelistMasterObserver
-
Perform the validation checks for a coprocessor to determine if the path is white listed or
not.
- verifyFileIntegrity(byte[], String) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.PersistentIOEngine
-
Verify cache files's integrity
- verifyOnDiskSizeMatchesHeader(int, ByteBuff, long, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
-
Verify the passed in onDiskSizeWithHeader aligns with what is in the header else something is
not right.
- verifyRegionInfo(RegionInfo, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Verify that the regionInfo is valid
- verifyRegionPlacement(boolean) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Verify the region placement is consistent with the assignment plan nnn
- verifyRegions(SnapshotManifest) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Check that all the regions in the snapshot are valid, and accounted for.
- VerifyReplication - Class in org.apache.hadoop.hbase.mapreduce.replication
-
This map-only job compares the data from a local table with a remote one.
- VerifyReplication() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- VerifyReplication.Verifier - Class in org.apache.hadoop.hbase.mapreduce.replication
-
Map-only comparator for 2 tables
- VerifyReplication.Verifier.Counters - Enum in org.apache.hadoop.hbase.mapreduce.replication
-
- verifySnapshot(Path, Set<String>) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Verify that the snapshot in the directory is a valid snapshot
- verifySnapshot(Configuration, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- verifySnapshot(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot
- verifySnapshot(Configuration, FileSystem, SnapshotManifest) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot
- verifySnapshotDescription(Path) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Check that the snapshot description written in the filesystem matches the current snapshot
- verifySource - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- verifySplitKeys(byte[][]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
-
- verifyStoreFile(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, RegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot store file
- verifyTableInfo(SnapshotManifest) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Check that the table descriptor for the snapshot is a valid table descriptor
- verifyTarget - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- VerifyWALEntriesReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
-
- VerifyWALEntriesReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
-
- version - Variable in class org.apache.hadoop.hbase.client.SnapshotDescription
-
- VERSION - Static variable in class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
- VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
- version - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
-
- VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
-
The Bloom filter version.
- VERSION - Static variable in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- Version(int) - Constructor for enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
-
- version - Variable in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
-
Version is volatile to ensure it is atomically read when not using a lock.
- VERSION - Static variable in class org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
-
- version - Variable in class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- version - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- VERSION - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- version - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- version - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- VERSION - Static variable in class org.apache.hadoop.hbase.ServerName
-
Version for this class.
- version - Variable in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- VERSION_BYTES - Static variable in class org.apache.hadoop.hbase.ServerName
-
- VERSION_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of version file
- VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often we should try to write a version file, before failing
- VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- versionedList - Variable in class org.apache.hadoop.hbase.regionserver.MemStoreCompactor
-
- VersionedSegmentsList - Class in org.apache.hadoop.hbase.regionserver
-
A list of segment managers coupled with the version of the memstore (version at the time it was
created).
- VersionedSegmentsList(List<ImmutableSegment>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
-
- VersionInfo - Class in org.apache.hadoop.hbase.util
-
This class finds the Version information for HBase.
- VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
-
- VersionInfoUtil - Class in org.apache.hadoop.hbase.client
-
Class to help with parsing the version info.
- VersionInfoUtil() - Constructor for class org.apache.hadoop.hbase.client.VersionInfoUtil
-
- VersionModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of the collection of versions of the REST gateway software components.
- VersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
-
Default constructor.
- VersionModel(ServletContext) - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
-
Constructor
- versionNumber - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder.ServerMetricsImpl
-
- versionNumber - Variable in class org.apache.hadoop.hbase.ServerMetricsBuilder
-
- versionNumberToString(int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
n * @return the passed-in version
int as a version String (e.g.
- versionReport() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- VersionResource - Class in org.apache.hadoop.hbase.rest
-
Implements REST software version reporting
- VersionResource() - Constructor for class org.apache.hadoop.hbase.rest.VersionResource
-
Constructor n
- VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- versions - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- versions - Variable in class org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
-
- versions - Variable in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- VERSIONS - Static variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- VERSIONS - Static variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- versions - Variable in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- versionsAfterFilter - Variable in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
-
- versionsToReturn(int) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- VERY_LARGE_NUMBER - Static variable in class org.apache.hadoop.hbase.util.VersionInfo
-
- victimCache - Variable in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
-
- victimHandler - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
-
Where to send victims (blocks evicted/missing from the cache).
- victimHandler - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Where to send victims (blocks evicted/missing from the cache).
- vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Encode a long value as a variable length integer.
- visExpResolver - Variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- VISIBILITY_EXP_RESOLVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- VISIBILITY_EXP_SERIALIZATION_FORMAT_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- VISIBILITY_LABEL_GENERATOR_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- VISIBILITY_LABEL_SERVICE_CLASS - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- VISIBILITY_LABEL_ZK_PATH - Static variable in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- VISIBILITY_LABELS_ATTR_KEY - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
The string that is used as key in setting the Operation attributes for visibility labels
- VISIBILITY_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- VISIBILITY_USER_AUTHS_ZK_PATH - Static variable in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- VisibilityClient - Class in org.apache.hadoop.hbase.security.visibility
-
Utility client for doing visibility labels admin operations.
- VisibilityClient() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
- VisibilityConstants - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityConstants() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- VisibilityController - Class in org.apache.hadoop.hbase.security.visibility
-
Coprocessor that has both the MasterObserver and RegionObserver implemented that supports in
visibility labels
- VisibilityController() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- VisibilityController.DeleteVersionVisibilityExpressionFilter - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityControllerNotReadyException - Exception in org.apache.hadoop.hbase.security.visibility
-
- VisibilityControllerNotReadyException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
-
- VisibilityDeleteVersionsNode(long, long, VisibilityNewVersionBehaivorTracker.TagInfo) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode
-
- VisibilityExpEvaluator - Interface in org.apache.hadoop.hbase.security.visibility
-
During the read (ie.
- VisibilityExpressionResolver - Interface in org.apache.hadoop.hbase.mapreduce
-
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
- VisibilityLabelFilter - Class in org.apache.hadoop.hbase.security.visibility
-
This Filter checks the visibility expression with each KV against visibility labels associated
with the scan.
- VisibilityLabelFilter(VisibilityExpEvaluator, Map<ByteRange, Integer>) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelFilter
-
- VisibilityLabelOrdinalProvider - Interface in org.apache.hadoop.hbase.security.visibility
-
- VisibilityLabelsCache - Class in org.apache.hadoop.hbase.security.visibility
-
Maintains the cache for visibility labels and also uses the zookeeper to update the labels in the
system.
- VisibilityLabelsCache(ZKWatcher, Configuration) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- visibilityLabelService - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- VisibilityLabelService - Interface in org.apache.hadoop.hbase.security.visibility
-
The interface which deals with visibility labels and user auths admin service as well as the cell
visibility expression storage part and read time evaluation.
- visibilityLabelService - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- visibilityLabelService - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityReplication
-
- VisibilityLabelServiceManager - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityLabelServiceManager() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- visibilityLabelsService - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- VisibilityLabelsValidator - Class in org.apache.hadoop.hbase.security.visibility
-
A simple validator that validates the labels passed
- VisibilityLabelsValidator() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- VisibilityNewVersionBehaivorTracker - Class in org.apache.hadoop.hbase.security.visibility
-
Similar to MvccSensitiveTracker but tracks the visibility expression also before deciding if a
Cell can be considered deleted
- VisibilityNewVersionBehaivorTracker(NavigableSet<byte[]>, CellComparator, int, int, int, long) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker
-
- VisibilityNewVersionBehaivorTracker.TagInfo - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityReplication - Class in org.apache.hadoop.hbase.security.visibility
-
A RegionServerObserver impl that provides the custom VisibilityReplicationEndpoint.
- VisibilityReplication() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityReplication
-
- VisibilityReplicationEndpoint - Class in org.apache.hadoop.hbase.security.visibility
-
- VisibilityReplicationEndpoint(ReplicationEndpoint, VisibilityLabelService) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- VisibilityScanDeleteTracker - Class in org.apache.hadoop.hbase.security.visibility
-
Similar to ScanDeletTracker but tracks the visibility expression also before deciding if a Cell
can be considered deleted
- VisibilityScanDeleteTracker(CellComparator) - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- visibilityTagsDeleteColumns - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- visibilityTagsDeleteFamily - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- visibilityTagsDeleteFamilyVersion - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- VisibilityUtils - Class in org.apache.hadoop.hbase.security.visibility
-
Utility method to support visibility
- VisibilityUtils() - Constructor for class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- visiblityTagsDeleteColumnVersion - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- visit(HDFSBlocksDistribution.HostAndWeight) - Method in interface org.apache.hadoop.hbase.HDFSBlocksDistribution.Visitor
-
- visit(Result) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
-
- visit(Result) - Method in class org.apache.hadoop.hbase.master.procedure.HBCKServerCrashProcedure.UnknownServerVisitor
-
- visit(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
-
- visit(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
-
- visit(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.TableVisitorBase
-
- visit(Result) - Method in interface org.apache.hadoop.hbase.MetaTableAccessor.Visitor
-
Visit the catalog table row.
- visit(int) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation.Visitor
-
- visit(TNode, AvlUtil.AvlNodeVisitor<TNode>) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
-
Visit each node of the tree
- visitBatchOperations(boolean, int, HRegion.BatchOperation.Visitor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
-
Helper method for visiting pending/ all batch operations
- visitBulkHFiles(FileSystem, Path, LoadIncrementalHFiles.BulkHFileVisitor<TFamily>) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Iterate over the bulkDir hfiles.
- visitBulkHFiles(FileSystem, Path, LoadIncrementalHFiles.BulkHFileVisitor<TFamily>, boolean) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
-
Deprecated.
Iterate over the bulkDir hfiles.
- visitInternal(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.DefaultVisitorBase
-
- visitLogEntryBeforeWrite(RegionInfo, WALKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
Called before each write.
- visitLogEntryBeforeWrite(RegionInfo, WALKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALActionListener
-
- visitMeta(RegionStateStore.RegionStateVisitor) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- visitMetaEntry(RegionStateStore.RegionStateVisitor, Result) - Static method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
- visitMetaForRegion(String, RegionStateStore.RegionStateVisitor) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStateStore
-
Queries META table for the passed region encoded name, delegating action upon results to the
RegionStateVisitor
passed as second parameter.
- visitNamespaceQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
-
- visitNode(TNode) - Method in interface org.apache.hadoop.hbase.util.AvlUtil.AvlNodeVisitor
-
Visitor
- visitor - Variable in class org.apache.hadoop.hbase.AsyncMetaTableAccessor.MetaTableScanResultConsumer
-
- visitReferencedFiles(Configuration, FileSystem, Path, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files
- visitReferencedFiles(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, SnapshotReferenceUtil.SnapshotVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files, restored.edits and logs
- visitRegionServerQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.RegionServerQuotasVisitor
-
- visitRegionState(Result, RegionInfo, RegionState.State, ServerName, ServerName, long) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionMetaLoadingVisitor
-
- visitRegionState(Result, RegionInfo, RegionState.State, ServerName, ServerName, long) - Method in interface org.apache.hadoop.hbase.master.assignment.RegionStateStore.RegionStateVisitor
-
- visitRegionStoreFiles(SnapshotProtos.SnapshotRegionManifest, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files in the specified region
- visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the region store files
- visitTableQuotas(TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
-
- visitTableStoreFiles(Configuration, FileSystem, Path, SnapshotProtos.SnapshotDescription, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
© Iterate over the snapshot store files
- visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the table store files
- visitUserQuotas(String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
-
- visitUserQuotas(String, TableName, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
-
- visitUserQuotas(String, String, QuotaProtos.Quotas) - Method in interface org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
-
- vLength - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- vLength - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- vlsClazzName - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- vOffset - Variable in class org.apache.hadoop.hbase.ExtendedCellBuilderImpl
-
- vOffset - Variable in class org.apache.hadoop.hbase.IndividualBytesFieldCell
-
- voidMutate(HBaseRpcController, HRegionLocation, ClientProtos.ClientService.Interface, REQ, RawAsyncTableImpl.Converter<ClientProtos.MutateRequest, byte[], REQ>) - Static method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-
- voidMutate(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
-