Uses of Class
org.apache.cassandra.utils.concurrent.AsyncFuture
-
-
Uses of AsyncFuture in org.apache.cassandra.concurrent
Subclasses of AsyncFuture in org.apache.cassandra.concurrent Modifier and Type Class Description class
FutureTask<V>
A FutureTask that utilises Cassandra'sAsyncFuture
, making it compatible withExecutorPlus
.class
FutureTaskWithResources<V>
A FutureTask that utilises Cassandra'sAsyncFuture
, making it compatible withExecutorPlus
. -
Uses of AsyncFuture in org.apache.cassandra.net
Subclasses of AsyncFuture in org.apache.cassandra.net Modifier and Type Class Description class
AsyncChannelPromise
SeeAsyncPromise
andChannelPromise
This class is all boiler plate, just ensuring we return ourselves and invoke the correct Promise method.class
AsyncOneResponse<T>
A callback specialized for returning a value from a single target; that is, this is for messages that we only send to one recipient. -
Uses of AsyncFuture in org.apache.cassandra.repair
Subclasses of AsyncFuture in org.apache.cassandra.repair Modifier and Type Class Description class
AsymmetricRemoteSyncTask
AsymmetricRemoteSyncTask sendsSyncRequest
to target node to repair(stream) data with other target replica.class
LocalSyncTask
LocalSyncTask performs streaming between local(coordinator) node and remote replica.class
RepairJob
RepairJob runs repair on given ColumnFamily.class
RepairSession
Coordinates the (active) repair of a list of non overlapping token ranges.static class
Scheduler.Task<T>
class
SnapshotTask
SnapshotTask is a task that sends snapshot request.class
SymmetricRemoteSyncTask
SymmetricRemoteSyncTask sendsSyncRequest
to remote(non-coordinator) node to repair(stream) data with other replica.class
SyncTask
class
ValidationTask
ValidationTask sendsValidationRequest
to a replica. -
Uses of AsyncFuture in org.apache.cassandra.service.paxos.cleanup
Subclasses of AsyncFuture in org.apache.cassandra.service.paxos.cleanup Modifier and Type Class Description class
PaxosCleanup
class
PaxosCleanupComplete
class
PaxosCleanupLocalCoordinator
class
PaxosCleanupSession
class
PaxosFinishPrepareCleanup
class
PaxosStartPrepareCleanup
Determines the highest ballot we should attempt to repair -
Uses of AsyncFuture in org.apache.cassandra.service.reads.repair
Subclasses of AsyncFuture in org.apache.cassandra.service.reads.repair Modifier and Type Class Description class
BlockingPartitionRepair
-
Uses of AsyncFuture in org.apache.cassandra.streaming
Subclasses of AsyncFuture in org.apache.cassandra.streaming Modifier and Type Class Description class
StreamResultFuture
A future on the result (StreamState
) of a streaming plan. -
Uses of AsyncFuture in org.apache.cassandra.utils.concurrent
Subclasses of AsyncFuture in org.apache.cassandra.utils.concurrent Modifier and Type Class Description class
AsyncPromise<V>
ExtendsAsyncFuture
to implement thePromise
interface.static class
AsyncPromise.WithExecutor<V>
class
FutureCombiner<T>
Netty's PromiseCombiner is not threadsafe, and we combine futures from multiple event executors.class
ImmediateFuture<V>
Methods in org.apache.cassandra.utils.concurrent that return AsyncFuture Modifier and Type Method Description AsyncFuture<V>
AsyncFuture. await()
Wait for this future to completeAwaitable.await()
-