Uses of Interface
org.apache.hadoop.hbase.Abortable
Packages that use Abortable
Package
Description
Provides HBase Client
Table of Contents
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of Abortable in org.apache.hadoop.hbase
Subinterfaces of Abortable in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterface
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Classes in org.apache.hadoop.hbase that implement AbortableModifier and TypeClassDescriptionclass
HBaseServerBase<R extends HBaseRpcServicesBase<?>>
Base class for hbase services, such as master or region server.static class
Deprecated.Subclass so can get at protected methods (none at moment).class
Basic mock region server services.Methods in org.apache.hadoop.hbase with parameters of type AbortableModifier and TypeMethodDescriptionMockRegionServerServices.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) -
Uses of Abortable in org.apache.hadoop.hbase.backup
Classes in org.apache.hadoop.hbase.backup that implement AbortableModifier and TypeClassDescriptionclass
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory. -
Uses of Abortable in org.apache.hadoop.hbase.backup.regionserver
Classes in org.apache.hadoop.hbase.backup.regionserver that implement AbortableModifier and TypeClassDescriptionclass
Handle running each of the individual tasks for completing a backup procedure on a region server. -
Uses of Abortable in org.apache.hadoop.hbase.client
Subinterfaces of Abortable in org.apache.hadoop.hbase.clientModifier and TypeInterfaceDescriptioninterface
The administrative API for HBase.interface
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.interface
Hbck fixup tool APIs.Classes in org.apache.hadoop.hbase.client that implement AbortableModifier and TypeClassDescription(package private) class
TheAdmin
implementation which is based on anAsyncAdmin
.(package private) class
The connection implementation based onAsyncConnection
.class
UseConnection.getHbck()
to obtain an instance ofHbck
instead of constructing an HBaseHbck directly.class
Wraps aConnection
to make it can't be closed or aborted. -
Uses of Abortable in org.apache.hadoop.hbase.client.locking
Fields in org.apache.hadoop.hbase.client.locking declared as AbortableMethods in org.apache.hadoop.hbase.client.locking with parameters of type AbortableModifier and TypeMethodDescriptionLockServiceClient.namespaceLock
(String namespace, String description, Abortable abort) LocCreate a new EntityLock object to acquire exclusive lock on a namespace.LockServiceClient.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.LockServiceClient.tableLock
(TableName tableName, boolean exclusive, String description, Abortable abort) Create a new EntityLock object to acquire an exclusive or shared lock on a table.Constructors in org.apache.hadoop.hbase.client.locking with parameters of type AbortableModifierConstructorDescription(package private)
EntityLock
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface stub, org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest request, Abortable abort) Abortable.abort() is called when the lease of the lock will expire. -
Uses of Abortable in org.apache.hadoop.hbase.coprocessor
Fields in org.apache.hadoop.hbase.coprocessor declared as AbortableConstructors in org.apache.hadoop.hbase.coprocessor with parameters of type Abortable -
Uses of Abortable in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as AbortableModifier and TypeFieldDescriptionprivate final Abortable
RpcExecutor.abortable
(package private) final Abortable
RpcHandler.abortable
private Abortable
SimpleRpcScheduler.abortable
Methods in org.apache.hadoop.hbase.ipc with parameters of type AbortableModifier and TypeMethodDescriptionprotected RpcHandler
FastPathBalancedQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandler
FastPathRWQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) protected RpcHandler
RpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) Override if providing alternate Handler implementation.Constructors in org.apache.hadoop.hbase.ipc with parameters of type AbortableModifierConstructorDescriptionBalancedQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) BalancedQueueRpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) FastPathBalancedQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) FastPathBalancedQueueRpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) (package private)
FastPathRpcHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable, Deque<FastPathRpcHandler> fastPathHandlerStack) FastPathRWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) MetaRWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) RpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) RpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) (package private)
RpcHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, Abortable abortable) RWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, Abortable abortable) SimpleRpcScheduler
(org.apache.hadoop.conf.Configuration conf, int handlerCount, int priorityHandlerCount, int replicationHandlerCount, int metaTransitionHandler, PriorityFunction priority, Abortable server, int highPriorityLevel) -
Uses of Abortable in org.apache.hadoop.hbase.master
Subinterfaces of Abortable in org.apache.hadoop.hbase.masterClasses in org.apache.hadoop.hbase.master that implement AbortableModifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Fields in org.apache.hadoop.hbase.master declared as AbortableModifier and TypeFieldDescriptionprivate Abortable
DrainingServerTracker.abortable
private final Abortable
MasterRegionServerList.abortable
Constructors in org.apache.hadoop.hbase.master with parameters of type AbortableModifierConstructorDescriptionDrainingServerTracker
(ZKWatcher watcher, Abortable abortable, ServerManager serverManager) MasterRegionServerList
(MasterRegion region, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.master.region
Fields in org.apache.hadoop.hbase.master.region declared as AbortableModifier and TypeFieldDescriptionprivate final Abortable
MasterRegionFlusherAndCompactor.abortable
Methods in org.apache.hadoop.hbase.master.region with parameters of type AbortableModifier and TypeMethodDescription(package private) static MasterRegionWALRoller
MasterRegionWALRoller.create
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path walRootDir, org.apache.hadoop.fs.Path globalWALRootDir, String archivedWALSuffix, long rollPeriodMs, long flushSize) Constructors in org.apache.hadoop.hbase.master.region with parameters of type AbortableModifierConstructorDescription(package private)
MasterRegionFlusherAndCompactor
(org.apache.hadoop.conf.Configuration conf, Abortable abortable, HRegion region, long flushSize, long flushPerChanges, long flushIntervalMs, int compactMin, org.apache.hadoop.fs.Path globalArchivePath, String archivedHFileSuffix) private
MasterRegionWALRoller
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path walRootDir, org.apache.hadoop.fs.Path globalWALRootDir, String archivedWALSuffix) -
Uses of Abortable in org.apache.hadoop.hbase.procedure.flush
Fields in org.apache.hadoop.hbase.procedure.flush declared as AbortableModifier and TypeFieldDescriptionprivate final Abortable
RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.abortable
Constructors in org.apache.hadoop.hbase.procedure.flush with parameters of type AbortableModifierConstructorDescription(package private)
FlushTableSubprocedurePool
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.regionserver
Subinterfaces of Abortable in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Classes in org.apache.hadoop.hbase.regionserver that implement AbortableModifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.Methods in org.apache.hadoop.hbase.regionserver with parameters of type AbortableModifier and TypeMethodDescriptionFifoRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server) MasterFifoRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server) RpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server) Constructs aRpcScheduler
.SimpleRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, PriorityFunction priority, Abortable server) HRegionServer.regionLock
(List<RegionInfo> regionInfo, String description, Abortable abort) RegionServerServices.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) Master based locks on namespaces/tables/regions. -
Uses of Abortable in org.apache.hadoop.hbase.regionserver.snapshot
Fields in org.apache.hadoop.hbase.regionserver.snapshot declared as AbortableModifier and TypeFieldDescriptionprivate final Abortable
RegionServerSnapshotManager.SnapshotSubprocedurePool.abortable
Constructors in org.apache.hadoop.hbase.regionserver.snapshot with parameters of type AbortableModifierConstructorDescription(package private)
SnapshotSubprocedurePool
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.regionserver.wal
Fields in org.apache.hadoop.hbase.regionserver.wal declared as AbortableConstructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type AbortableModifierConstructorDescriptionprotected
AbstractFSWAL
(org.apache.hadoop.fs.FileSystem fs, Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir) AsyncFSWAL
(org.apache.hadoop.fs.FileSystem fs, Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, org.apache.hbase.thirdparty.io.netty.channel.EventLoopGroup eventLoopGroup, Class<? extends org.apache.hbase.thirdparty.io.netty.channel.Channel> channelClass, StreamSlowMonitor monitor) FSHLog
(org.apache.hadoop.fs.FileSystem fs, Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir) Create an edit log at the givendir
location.FSHLog
(org.apache.hadoop.fs.FileSystem fs, Abortable abortable, org.apache.hadoop.fs.Path root, String logDir, org.apache.hadoop.conf.Configuration conf) -
Uses of Abortable in org.apache.hadoop.hbase.replication
Classes in org.apache.hadoop.hbase.replication that implement AbortableModifier and TypeClassDescriptionclass
ABaseReplicationEndpoint
for replication endpoints whose target cluster is an HBase cluster.Fields in org.apache.hadoop.hbase.replication declared as AbortableMethods in org.apache.hadoop.hbase.replication that return AbortableConstructors in org.apache.hadoop.hbase.replication with parameters of type AbortableModifierConstructorDescriptionContext
(Server server, org.apache.hadoop.conf.Configuration localConf, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, String peerId, UUID clusterId, ReplicationPeer replicationPeer, MetricsSource metrics, TableDescriptors tableDescriptors, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.replication.regionserver
Classes in org.apache.hadoop.hbase.replication.regionserver that implement AbortableModifier and TypeClassDescriptionclass
AReplicationEndpoint
implementation for replicating to another HBase cluster.private static final class
-
Uses of Abortable in org.apache.hadoop.hbase.thrift2.client
Classes in org.apache.hadoop.hbase.thrift2.client that implement Abortable -
Uses of Abortable in org.apache.hadoop.hbase.wal
Classes in org.apache.hadoop.hbase.wal with type parameters of type AbortableModifier and TypeClassDescriptionclass
AbstractWALRoller<T extends Abortable>
Runs periodically to determine if the WAL should be rolled.Fields in org.apache.hadoop.hbase.wal declared as AbortableModifier and TypeFieldDescriptionprotected Abortable
AbstractWALProvider.abortable
protected final T
AbstractWALRoller.abortable
private final Abortable
LazyInitializedWALProvider.abortable
(package private) final Abortable
WALFactory.abortable
Methods in org.apache.hadoop.hbase.wal with parameters of type AbortableModifier and TypeMethodDescriptionfinal void
AbstractWALProvider.init
(WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, Abortable server) void
DisabledWALProvider.init
(WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, Abortable abortable) void
WALProvider.init
(WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, Abortable server) Set up the provider to create wals.Constructors in org.apache.hadoop.hbase.wal with parameters of type AbortableModifierConstructorDescription(package private)
LazyInitializedWALProvider
(WALFactory factory, String providerId, String providerConfigName, Abortable abortable) private
WALFactory
(org.apache.hadoop.conf.Configuration conf, String factoryId, Abortable abortable) WALFactory
(org.apache.hadoop.conf.Configuration conf, ServerName serverName, Abortable abortable) Create a WALFactory. -
Uses of Abortable in org.apache.hadoop.hbase.zookeeper
Classes in org.apache.hadoop.hbase.zookeeper that implement AbortableFields in org.apache.hadoop.hbase.zookeeper declared as AbortableModifier and TypeFieldDescriptionprivate final Abortable
ZKClusterId.abortable
protected final Abortable
ZKNodeTracker.abortable
Used to abort if a fatal error occursprotected Abortable
ZKWatcher.abortable
Constructors in org.apache.hadoop.hbase.zookeeper with parameters of type AbortableModifierConstructorDescriptionClusterStatusTracker
(ZKWatcher watcher, Abortable abortable) Creates a cluster status tracker.MasterAddressTracker
(ZKWatcher watcher, Abortable abortable) Construct a master address listener with the specifiedzookeeper
reference.ZKClusterId
(ZKWatcher watcher, Abortable abortable) ZKNodeTracker
(ZKWatcher watcher, String node, Abortable abortable) Constructs a new ZK node tracker.Instantiate a ZooKeeper connection and watcher.ZKWatcher
(org.apache.hadoop.conf.Configuration conf, String identifier, Abortable abortable, boolean canCreateBaseZNode) Instantiate a ZooKeeper connection and watcher.ZKWatcher
(org.apache.hadoop.conf.Configuration conf, String identifier, Abortable abortable, boolean canCreateBaseZNode, boolean clientZK) Instantiate a ZooKeeper connection and watcher.