Uses of Class
org.apache.hadoop.hbase.regionserver.wal.SyncFuture
-
Uses of SyncFuture in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeFieldDescriptionprivate SyncFuture
RingBufferTruck.sync
Either this syncFuture is set or entry is set, but not both.private final SyncFuture[]
FSHLog.RingBufferEventHandler.syncFutures
private SyncFuture
FSHLog.SyncRunner.takeSyncFuture
Modifier and TypeFieldDescriptionprivate static final Comparator<SyncFuture>
AsyncFSWAL.SEQ_COMPARATOR
private final org.apache.hbase.thirdparty.com.google.common.cache.Cache<Thread,
SyncFuture> SyncFutureCache.syncFutureCache
private final SortedSet<SyncFuture>
AsyncFSWAL.syncFutures
private final BlockingQueue<SyncFuture>
FSHLog.SyncRunner.syncFutures
Modifier and TypeMethodDescriptionSyncFutureCache.getIfPresentOrNew()
protected final 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 itsSyncFuture
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 TypeMethodDescriptionprotected final void
AbstractFSWAL.blockOnSync
(SyncFuture syncFuture) private void
FSHLog.SafePointZigZagLatch.checkIfSyncFailed
(SyncFuture syncFuture) (package private) void
RingBufferTruck.load
(SyncFuture syncFuture) Load the truck with aSyncFuture
.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 passedsyncFuture
(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.