Modifier and Type | Method and Description |
---|---|
(package private) void |
HMaster.assignMeta(MonitoredTask status,
Set<ServerName> previouslyFailedMetaRSs,
int replicaId)
Check
hbase:meta is assigned. |
(package private) boolean |
ActiveMasterManager.blockUntilBecomingActiveMaster(int checkInterval,
MonitoredTask startupStatus)
Block until becoming the active master.
|
private void |
HMaster.finishActiveMasterInitialization(MonitoredTask status)
Finish initialization of HMaster after becoming the primary master.
|
void |
ServerManager.waitForRegionServers(MonitoredTask status)
Wait for the region servers to report in.
|
private void |
SplitLogManager.waitForSplittingCompletion(SplitLogManager.TaskBatch batch,
MonitoredTask status) |
Modifier and Type | Field and Description |
---|---|
protected MonitoredTask |
TakeSnapshotHandler.status |
private MonitoredTask |
CloneSnapshotHandler.status |
private MonitoredTask |
RestoreSnapshotHandler.status |
Modifier and Type | Interface and Description |
---|---|
interface |
MonitoredRPCHandler
A MonitoredTask implementation optimized for use with RPC Handlers
handling frequent, short duration tasks.
|
Modifier and Type | Class and Description |
---|---|
class |
MonitoredRPCHandlerImpl
A MonitoredTask implementation designed for use with RPC Handlers
handling frequent, short duration tasks.
|
(package private) class |
MonitoredTaskImpl |
Modifier and Type | Field and Description |
---|---|
private MonitoredTask |
TaskMonitor.TaskAndWeakRefPair.impl |
Modifier and Type | Field and Description |
---|---|
private WeakReference<MonitoredTask> |
TaskMonitor.TaskAndWeakRefPair.weakProxy |
Modifier and Type | Method and Description |
---|---|
MonitoredTask |
MonitoredTask.clone()
Public exposure of Object.clone() in order to allow clients to easily
capture current state.
|
MonitoredTask |
TaskMonitor.createStatus(String description) |
MonitoredTask |
TaskMonitor.TaskAndWeakRefPair.get() |
Modifier and Type | Method and Description |
---|---|
List<MonitoredTask> |
TaskMonitor.getTasks()
Produces a list containing copies of the current state of all non-expired
MonitoredTasks handled by this TaskMonitor.
|
Modifier and Type | Method and Description |
---|---|
private boolean |
TaskMonitor.canPurge(MonitoredTask stat) |
Constructor and Description |
---|
TaskMonitor.TaskAndWeakRefPair(MonitoredTask stat,
MonitoredTask proxy) |
Modifier and Type | Method and Description |
---|---|
boolean |
StoreFlushContext.commit(MonitoredTask status)
Commit the flush - add the store file to the store and clear the
memstore snapshot.
|
boolean |
HStore.StoreFlusherImpl.commit(MonitoredTask status) |
private StoreFile |
HStore.commitFile(org.apache.hadoop.fs.Path path,
long logCacheFlushId,
MonitoredTask status) |
private Map<byte[],List<StoreFile>> |
HRegion.doClose(boolean abort,
MonitoredTask status) |
protected void |
StoreFlusher.finalizeWriter(StoreFile.Writer writer,
long cacheFlushSeqNum,
MonitoredTask status) |
protected List<org.apache.hadoop.fs.Path> |
HStore.flushCache(long logCacheFlushId,
MemStoreSnapshot snapshot,
MonitoredTask status)
Write out current snapshot.
|
void |
StoreFlushContext.flushCache(MonitoredTask status)
Flush the cache (create the new store file)
A length operation which doesn't require locking out any function
of the store.
|
void |
HStore.StoreFlusherImpl.flushCache(MonitoredTask status) |
List<org.apache.hadoop.fs.Path> |
StripeStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot,
long cacheFlushSeqNum,
MonitoredTask status) |
abstract List<org.apache.hadoop.fs.Path> |
StoreFlusher.flushSnapshot(MemStoreSnapshot snapshot,
long cacheFlushSeqNum,
MonitoredTask status)
Turns a snapshot of memstore into a set of store files.
|
List<org.apache.hadoop.fs.Path> |
DefaultStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot,
long cacheFlushId,
MonitoredTask status) |
private long |
HRegion.initializeRegionInternals(CancelableProgressable reporter,
MonitoredTask status) |
private long |
HRegion.initializeStores(CancelableProgressable reporter,
MonitoredTask status)
Open all Stores.
|
private Region.FlushResult |
HRegion.internalFlushcache(Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker)
Flushing given stores.
|
private Region.FlushResult |
HRegion.internalFlushcache(MonitoredTask status)
Flushing all stores.
|
protected Region.FlushResult |
HRegion.internalFlushcache(WAL wal,
long myseqid,
Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker)
Flush the memstore.
|
protected Region.FlushResult |
HRegion.internalFlushCacheAndCommit(WAL wal,
MonitoredTask status,
HRegion.PrepareFlushResult prepareResult,
Collection<Store> storesToFlush) |
protected HRegion.PrepareFlushResult |
HRegion.internalPrepareFlushCache(WAL wal,
long myseqid,
Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker) |
protected long |
HRegion.replayRecoveredEditsIfAny(org.apache.hadoop.fs.Path regiondir,
Map<byte[],Long> maxSeqIdInStores,
CancelableProgressable reporter,
MonitoredTask status)
Read the edits put under this region by wal splitting process.
|
Modifier and Type | Field and Description |
---|---|
private MonitoredTask |
RestoreSnapshotHelper.status |
Constructor and Description |
---|
RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
SnapshotManifest manifest,
HTableDescriptor tableDescriptor,
org.apache.hadoop.fs.Path rootDir,
ForeignExceptionDispatcher monitor,
MonitoredTask status) |
RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
SnapshotManifest manifest,
HTableDescriptor tableDescriptor,
org.apache.hadoop.fs.Path rootDir,
ForeignExceptionDispatcher monitor,
MonitoredTask status,
boolean createBackRefs) |
Modifier and Type | Field and Description |
---|---|
private MonitoredTask |
WALSplitter.status |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.