Modifier and Type | Class and Description |
---|---|
class |
FutureTask<V>
A FutureTask that utilises Cassandra's
AsyncFuture , making it compatible with ExecutorPlus . |
class |
FutureTaskWithResources<V>
A FutureTask that utilises Cassandra's
AsyncFuture , making it compatible with ExecutorPlus . |
class |
SyncFutureTask<T> |
Modifier and Type | Class and Description |
---|---|
class |
AsyncChannelPromise
See
AsyncPromise and ChannelPromise
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AsymmetricRemoteSyncTask
AsymmetricRemoteSyncTask sends
SyncRequest 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.
|
class |
SnapshotTask
SnapshotTask is a task that sends snapshot request.
|
class |
SymmetricRemoteSyncTask
SymmetricRemoteSyncTask sends
SyncRequest to remote(non-coordinator) node
to repair(stream) data with other replica. |
class |
SyncTask |
class |
ValidationTask
ValidationTask sends
ValidationRequest to a replica. |
Modifier and Type | Class and Description |
---|---|
class |
PaxosCleanup |
class |
PaxosCleanupComplete |
class |
PaxosCleanupLocalCoordinator |
class |
PaxosCleanupSession |
class |
PaxosFinishPrepareCleanup |
class |
PaxosStartPrepareCleanup
Determines the highest ballot we should attempt to repair
|
Modifier and Type | Class and Description |
---|---|
class |
BlockingPartitionRepair |
Modifier and Type | Class and Description |
---|---|
class |
StreamResultFuture
A future on the result (
StreamState ) of a streaming plan. |
Modifier and Type | Class and Description |
---|---|
class |
AsyncFuture<V>
Our default
Future implementation, with all state being managed without locks (except those used by the JVM). |
class |
AsyncPromise<V>
Extends
AsyncFuture to implement the Promise 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> |
class |
SyncFuture<V>
Netty's DefaultPromise uses a mutex to coordinate notifiers AND waiters between the eventLoop and the other threads.
|
class |
SyncPromise<V>
Extends
SyncFuture to implement the Promise interface. |
static class |
SyncPromise.WithExecutor<V> |
Modifier and Type | Method and Description |
---|---|
AbstractFuture<V> |
AbstractFuture.addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> callback)
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor) natively
See addListener(GenericFutureListener) for ordering semantics. |
AbstractFuture<V> |
AbstractFuture.addCallback(java.util.function.Consumer<? super V> onSuccess,
java.util.function.Consumer<? super java.lang.Throwable> onFailure)
Support more fluid version of
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
See addListener(GenericFutureListener) for ordering semantics. |
AbstractFuture<V> |
AbstractFuture.addCallback(java.util.function.Consumer<? super V> onSuccess,
java.util.function.Consumer<? super java.lang.Throwable> onFailure,
java.util.concurrent.Executor executor)
Support more fluid version of
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
See addListener(GenericFutureListener) for ordering semantics. |
AbstractFuture<V> |
AbstractFuture.addCallback(com.google.common.util.concurrent.FutureCallback<? super V> callback)
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor) natively
See addListener(GenericFutureListener) for ordering semantics. |
AbstractFuture<V> |
AbstractFuture.addCallback(com.google.common.util.concurrent.FutureCallback<? super V> callback,
java.util.concurrent.Executor executor)
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor) natively
See addListener(GenericFutureListener) for ordering semantics. |
Modifier and Type | Method and Description |
---|---|
protected <T> Future<T> |
AbstractFuture.flatMap(AbstractFuture<T> result,
java.util.function.Function<? super V,? extends Future<T>> flatMapper,
java.util.concurrent.Executor executor)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See addListener(GenericFutureListener) for ordering semantics. |
protected <T> Future<T> |
AbstractFuture.map(AbstractFuture<T> result,
java.util.function.Function<? super V,? extends T> mapper,
java.util.concurrent.Executor executor)
Support
Futures.transform(ListenableFuture, com.google.common.base.Function, Executor) natively
See addListener(GenericFutureListener) for ordering semantics. |
Copyright © 2009-2022 The Apache Software Foundation