public class PaxosCleanupComplete extends AsyncFuture<java.lang.Void> implements RequestCallbackWithFailure<java.lang.Void>, java.lang.Runnable
Awaitable.AbstractAwaitable, Awaitable.AsyncAwaitable, Awaitable.Defaults, Awaitable.SyncAwaitable
Modifier and Type | Field and Description |
---|---|
static IVersionedSerializer<org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete.Request> |
serializer |
static IVerbHandler<org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete.Request> |
verbHandler |
CANCELLED, UNCANCELLABLE, UNSET
Modifier and Type | Method and Description |
---|---|
void |
onFailure(InetAddressAndPort from,
RequestFailureReason reason)
Called when there is an exception on the remote node or timeout happens
|
void |
onResponse(Message<java.lang.Void> msg) |
void |
run() |
await, awaitUntil, flatMap, map
addCallback, addCallback, addCallback, addCallback, addCallback, addCallback, addListener, addListener, addListener, addListeners, await, awaitThrowUncheckedOnInterrupt, awaitThrowUncheckedOnInterrupt, awaitUninterruptibly, awaitUninterruptibly, awaitUntilThrowUncheckedOnInterrupt, awaitUntilUninterruptibly, cancel, cause, description, flatMap, get, get, getNow, getWhenDone, isCancellable, isCancelled, isDone, isSuccess, isUncancellable, map, map, notifyExecutor, removeListener, removeListeners, setUncancellable, setUncancellableExclusive, toString, tryFailure, trySuccess
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
invokeOnFailure
trackLatencyForSnitch
await, awaitUninterruptibly, flatMap, rethrowIfFailed, sync, syncThrowUncheckedOnInterrupt, syncUninterruptibly
public static final IVersionedSerializer<org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete.Request> serializer
public static final IVerbHandler<org.apache.cassandra.service.paxos.cleanup.PaxosCleanupComplete.Request> verbHandler
public void run()
run
in interface java.lang.Runnable
public void onFailure(InetAddressAndPort from, RequestFailureReason reason)
RequestCallbackWithFailure
onFailure
in interface RequestCallback<java.lang.Void>
onFailure
in interface RequestCallbackWithFailure<java.lang.Void>
public void onResponse(Message<java.lang.Void> msg)
onResponse
in interface RequestCallback<java.lang.Void>
msg
- response received.Copyright © 2009- The Apache Software Foundation