Package | Description |
---|---|
org.apache.hadoop.hbase.regionserver.wal |
Modifier and Type | Field and Description |
---|---|
private SyncFuture |
RingBufferTruck.sync
Either this syncFuture is set or entry is set, but not both.
|
private SyncFuture[] |
FSHLog.RingBufferEventHandler.syncFutures |
private SyncFuture |
FSHLog.SyncRunner.takeSyncFuture |
Modifier and Type | Field and Description |
---|---|
private static Comparator<SyncFuture> |
AsyncFSWAL.SEQ_COMPARATOR |
private org.apache.hbase.thirdparty.com.google.common.cache.Cache<Thread,SyncFuture> |
SyncFutureCache.syncFutureCache |
private SortedSet<SyncFuture> |
AsyncFSWAL.syncFutures |
private BlockingQueue<SyncFuture> |
FSHLog.SyncRunner.syncFutures |
Modifier and Type | Method and Description |
---|---|
SyncFuture |
SyncFutureCache.getIfPresentOrNew() |
protected SyncFuture |
AbstractFSWAL.getSyncFuture(long sequence,
boolean forceSync) |
private SyncFuture |
FSHLog.publishSyncOnRingBuffer(boolean forceSync) |
protected SyncFuture |
FSHLog.publishSyncOnRingBuffer(long sequence,
boolean forceSync) |
(package private) SyncFuture |
SyncFuture.reset(long txid,
boolean forceSync)
Call this method to clear old usage and get it ready for new deploy.
|
(package private) SyncFuture |
RingBufferTruck.unloadSync()
Unload the truck of its
SyncFuture payload. |
(package private) SyncFuture |
FSHLog.SafePointZigZagLatch.waitSafePoint(SyncFuture syncFuture)
For Thread A to call when it is ready to wait on the 'safe point' to be attained.
|
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractFSWAL.blockOnSync(SyncFuture syncFuture) |
private void |
FSHLog.SafePointZigZagLatch.checkIfSyncFailed(SyncFuture syncFuture) |
(package private) void |
RingBufferTruck.load(SyncFuture syncFuture)
Load the truck with a
SyncFuture . |
private void |
AsyncFSWAL.markFutureDoneAndOffer(SyncFuture future,
long txid,
Throwable t)
Helper that marks the future as DONE and offers it back to the cache.
|
(package private) void |
FSHLog.SyncRunner.offer(long sequence,
SyncFuture[] syncFutures,
int syncFutureCount) |
void |
SyncFutureCache.offer(SyncFuture syncFuture)
Offers the sync future back to the cache for reuse.
|
private int |
FSHLog.SyncRunner.releaseSyncFuture(SyncFuture syncFuture,
long currentSequence,
Throwable t)
Release the passed
syncFuture |
(package private) SyncFuture |
FSHLog.SafePointZigZagLatch.waitSafePoint(SyncFuture syncFuture)
For Thread A to call when it is ready to wait on the 'safe point' to be attained.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.