Uses of Interface
org.apache.hadoop.hbase.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
Modifier and TypeInterfaceDescriptioninterface
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Modifier and TypeClassDescriptionclass
Wraps a Connection to make it can't be closed or aborted. -
Uses of Abortable in org.apache.hadoop.hbase.backup
Modifier 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
Modifier 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
Modifier and TypeInterfaceDescriptioninterface
The administrative API for HBase.interface
Internal methods on Connection that should not be used by user code.interface
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.interface
Hbck fixup tool APIs.Modifier and TypeClassDescriptionclass
Main implementation ofConnection
andClusterConnection
interfaces.(package private) static class
Some tests shut down the master.class
HBaseAdmin is no longer a client API.class
UseConnection.getHbck()
to obtain an instance ofHbck
instead of constructing an HBaseHbck directly.static final class
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. -
Uses of Abortable in org.apache.hadoop.hbase.client.locking
Modifier 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.ModifierConstructorDescription(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
-
Uses of Abortable in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprivate final Abortable
RpcExecutor.abortable
(package private) final Abortable
RpcHandler.abortable
private Abortable
SimpleRpcScheduler.abortable
Modifier 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.ModifierConstructorDescriptionBalancedQueueRpcExecutor
(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
Modifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Modifier and TypeFieldDescriptionprivate Abortable
DrainingServerTracker.abortable
private final Abortable
MasterRegionServerList.abortable
ModifierConstructorDescriptionDrainingServerTracker
(ZKWatcher watcher, Abortable abortable, ServerManager serverManager) MasterRegionServerList
(MasterRegion region, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.master.region
Modifier and TypeFieldDescriptionprivate final Abortable
MasterRegionFlusherAndCompactor.abortable
Modifier 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) ModifierConstructorDescription(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
Modifier and TypeFieldDescriptionprivate final Abortable
RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool.abortable
ModifierConstructorDescription(package private)
FlushTableSubprocedurePool
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.regionserver
Modifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Modifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.Modifier 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> regionInfos, 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
Modifier and TypeFieldDescriptionprivate final Abortable
RegionServerSnapshotManager.SnapshotSubprocedurePool.abortable
ModifierConstructorDescription(package private)
SnapshotSubprocedurePool
(String name, org.apache.hadoop.conf.Configuration conf, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.regionserver.wal
ModifierConstructorDescriptionprotected
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) 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.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) 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
Modifier and TypeClassDescriptionclass
ABaseReplicationEndpoint
for replication endpoints whose target cluster is an HBase cluster.ModifierConstructorDescriptionContext
(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
Modifier and TypeClassDescriptionprivate static class
class
AReplicationEndpoint
implementation for replicating to another HBase cluster.class
AReplicationEndpoint
endpoint which receives the WAL edits from the WAL, and sends the edits to replicas of regions.(package private) class
-
Uses of Abortable in org.apache.hadoop.hbase.thrift2.client
-
Uses of Abortable in org.apache.hadoop.hbase.wal
Modifier and TypeClassDescriptionclass
AbstractWALRoller<T extends Abortable>
Runs periodically to determine if the WAL should be rolled.Modifier and TypeFieldDescriptionprotected Abortable
AbstractFSWALProvider.abortable
protected final T
AbstractWALRoller.abortable
(package private) final Abortable
WALFactory.abortable
Modifier and TypeMethodDescriptionvoid
AbstractFSWALProvider.init
(WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, Abortable abortable) void
DisabledWALProvider.init
(WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, Abortable abortable) void
RegionGroupingProvider.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 abortable) Set up the provider to create wals.ModifierConstructorDescriptionWALFactory
(org.apache.hadoop.conf.Configuration conf, String factoryId, Abortable abortable) -
Uses of Abortable in org.apache.hadoop.hbase.zookeeper
Modifier and TypeFieldDescriptionprivate final Abortable
ZKClusterId.abortable
protected final Abortable
ZKNodeTracker.abortable
Used to abort if a fatal error occursprotected Abortable
ZKWatcher.abortable
ModifierConstructorDescriptionClusterStatusTracker
(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.