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 org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.Server
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.SharedConnection
Wraps a Connection to make it can't be closed or aborted. -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.backup
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.backup.BackupHFileCleaner
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory. -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.client
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.client.Admin
The administrative API for HBase.interface
org.apache.hadoop.hbase.client.ClusterConnection
Internal methods on Connection that should not be used by user code.interface
org.apache.hadoop.hbase.client.Connection
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.interface
org.apache.hadoop.hbase.client.Hbck
Hbck fixup tool APIs.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.ConnectionImplementation
Main implementation ofConnection
andClusterConnection
interfaces.class
org.apache.hadoop.hbase.client.HBaseAdmin
HBaseAdmin is no longer a client API.class
org.apache.hadoop.hbase.client.HBaseHbck
UseConnection.getHbck()
to obtain an instance ofHbck
instead of constructing an HBaseHbck directly.static final class
org.apache.hadoop.hbase.client.ServerConnectionUtils.ShortCircuitingClusterConnection
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 org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.client.locking
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.locking.EntityLock
LockServiceClient.namespaceLock
(String namespace, String description, org.apache.hadoop.hbase.Abortable abort) LocCreate a new EntityLock object to acquire exclusive lock on a namespace.org.apache.hadoop.hbase.client.locking.EntityLock
LockServiceClient.regionLock
(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.org.apache.hadoop.hbase.client.locking.EntityLock
LockServiceClient.tableLock
(org.apache.hadoop.hbase.TableName tableName, boolean exclusive, String description, org.apache.hadoop.hbase.Abortable abort) Create a new EntityLock object to acquire an exclusive or shared lock on a table. -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.coprocessor
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.Abortable
CoprocessorHost.abortable
ModifierConstructorDescriptionCoprocessorHost
(org.apache.hadoop.hbase.Abortable abortable) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.ipc
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.ipc.RpcHandler
FastPathBalancedQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) protected org.apache.hadoop.hbase.ipc.RpcHandler
FastPathRWQueueRpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) protected org.apache.hadoop.hbase.ipc.RpcHandler
RpcExecutor.getHandler
(String name, double handlerFailureThreshhold, int handlerCount, BlockingQueue<org.apache.hadoop.hbase.ipc.CallRunner> q, AtomicInteger activeHandlerCount, AtomicInteger failedHandlerCount, org.apache.hadoop.hbase.Abortable abortable) Override if providing alternate Handler implementation.ModifierConstructorDescriptionBalancedQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) BalancedQueueRpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) FastPathBalancedQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) FastPathBalancedQueueRpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) FastPathRWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) MetaRWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) RpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) RpcExecutor
(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) RWQueueRpcExecutor
(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable) SimpleRpcScheduler
(org.apache.hadoop.conf.Configuration conf, int handlerCount, int priorityHandlerCount, int replicationHandlerCount, int metaTransitionHandler, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server, int highPriorityLevel) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.master
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.master.MasterServices
A curated subset of services provided byHMaster
.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.master.HMaster
HMaster is the "master server" for HBase.static class
org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
ModifierConstructorDescriptionDrainingServerTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.hbase.master.ServerManager serverManager) MasterRegionServerList
(org.apache.hadoop.hbase.master.region.MasterRegion region, org.apache.hadoop.hbase.Abortable abortable) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.regionserver
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.regionserver.RegionServerServices
A curated subset of services provided byHRegionServer
.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.HRegionServer
HRegionServer makes a set of HRegions available to clients.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ipc.RpcScheduler
FifoRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server) org.apache.hadoop.hbase.ipc.RpcScheduler
MasterFifoRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server) org.apache.hadoop.hbase.ipc.RpcScheduler
RpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server) Constructs aRpcScheduler
.org.apache.hadoop.hbase.ipc.RpcScheduler
SimpleRpcSchedulerFactory.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server) org.apache.hadoop.hbase.client.locking.EntityLock
HRegionServer.regionLock
(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) org.apache.hadoop.hbase.client.locking.EntityLock
RegionServerServices.regionLock
(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) Master based locks on namespaces/tables/regions. -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.Abortable
AbstractFSWAL.abortable
ModifierConstructorDescriptionprotected
AbstractFSWAL
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<org.apache.hadoop.hbase.regionserver.wal.WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix) AsyncFSWAL
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<org.apache.hadoop.hbase.regionserver.wal.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, org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor monitor) FSHLog
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<org.apache.hadoop.hbase.regionserver.wal.WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix) Create an edit log at the givendir
location.FSHLog
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.fs.Path root, String logDir, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.replication
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
ABaseReplicationEndpoint
for replication endpoints whose target cluster is an HBase cluster.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Abortable
ReplicationEndpoint.Context.getAbortable()
ModifierConstructorDescriptionContext
(org.apache.hadoop.conf.Configuration localConf, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, String peerId, UUID clusterId, org.apache.hadoop.hbase.replication.ReplicationPeer replicationPeer, org.apache.hadoop.hbase.replication.regionserver.MetricsSource metrics, org.apache.hadoop.hbase.TableDescriptors tableDescriptors, org.apache.hadoop.hbase.Abortable abortable) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.wal
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.wal.AbstractWALRoller<T extends org.apache.hadoop.hbase.Abortable>
Runs periodically to determine if the WAL should be rolled.Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.Abortable
AbstractFSWALProvider.abortable
protected final T
AbstractWALRoller.abortable
Modifier and TypeMethodDescriptionvoid
AbstractFSWALProvider.init
(org.apache.hadoop.hbase.wal.WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, org.apache.hadoop.hbase.Abortable abortable) void
RegionGroupingProvider.init
(org.apache.hadoop.hbase.wal.WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, org.apache.hadoop.hbase.Abortable abortable) void
WALProvider.init
(org.apache.hadoop.hbase.wal.WALFactory factory, org.apache.hadoop.conf.Configuration conf, String providerId, org.apache.hadoop.hbase.Abortable abortable) Set up the provider to create wals.ModifierConstructorDescriptionWALFactory
(org.apache.hadoop.conf.Configuration conf, String factoryId, org.apache.hadoop.hbase.Abortable abortable) -
Uses of org.apache.hadoop.hbase.Abortable in org.apache.hadoop.hbase.zookeeper
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.zookeeper.ZKWatcher
Acts as the single ZooKeeper Watcher.Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.Abortable
ZKNodeTracker.abortable
Used to abort if a fatal error occursprotected org.apache.hadoop.hbase.Abortable
ZKWatcher.abortable
ModifierConstructorDescriptionClusterStatusTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) Creates a cluster status tracker.MasterAddressTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) Construct a master address listener with the specifiedzookeeper
reference.ZKClusterId
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) ZKNodeTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String node, org.apache.hadoop.hbase.Abortable abortable) Constructs a new ZK node tracker.ZKWatcher
(org.apache.hadoop.conf.Configuration conf, String identifier, org.apache.hadoop.hbase.Abortable abortable) Instantiate a ZooKeeper connection and watcher.ZKWatcher
(org.apache.hadoop.conf.Configuration conf, String identifier, org.apache.hadoop.hbase.Abortable abortable, boolean canCreateBaseZNode) Instantiate a ZooKeeper connection and watcher.ZKWatcher
(org.apache.hadoop.conf.Configuration conf, String identifier, org.apache.hadoop.hbase.Abortable abortable, boolean canCreateBaseZNode, boolean clientZK) Instantiate a ZooKeeper connection and watcher.