Uses of Class
org.apache.cassandra.utils.concurrent.AbstractFuture
-
-
Uses of AbstractFuture in org.apache.cassandra.concurrent
Subclasses of AbstractFuture in org.apache.cassandra.concurrent Modifier and Type Class Description classFutureTask<V>A FutureTask that utilises Cassandra'sAsyncFuture, making it compatible withExecutorPlus.classFutureTaskWithResources<V>A FutureTask that utilises Cassandra'sAsyncFuture, making it compatible withExecutorPlus.classSyncFutureTask<T> -
Uses of AbstractFuture in org.apache.cassandra.net
Subclasses of AbstractFuture in org.apache.cassandra.net Modifier and Type Class Description classAsyncChannelPromiseSeeAsyncPromiseandChannelPromiseThis class is all boiler plate, just ensuring we return ourselves and invoke the correct Promise method.classAsyncOneResponse<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 AbstractFuture in org.apache.cassandra.repair
Subclasses of AbstractFuture in org.apache.cassandra.repair Modifier and Type Class Description classAsymmetricRemoteSyncTaskAsymmetricRemoteSyncTask sendsSyncRequestto target node to repair(stream) data with other target replica.classLocalSyncTaskLocalSyncTask performs streaming between local(coordinator) node and remote replica.classRepairJobRepairJob runs repair on given ColumnFamily.classRepairSessionCoordinates the (active) repair of a list of non overlapping token ranges.static classScheduler.Task<T>classSnapshotTaskSnapshotTask is a task that sends snapshot request.classSymmetricRemoteSyncTaskSymmetricRemoteSyncTask sendsSyncRequestto remote(non-coordinator) node to repair(stream) data with other replica.classSyncTaskclassValidationTaskValidationTask sendsValidationRequestto a replica. -
Uses of AbstractFuture in org.apache.cassandra.service.paxos.cleanup
Subclasses of AbstractFuture in org.apache.cassandra.service.paxos.cleanup Modifier and Type Class Description classPaxosCleanupclassPaxosCleanupCompleteclassPaxosCleanupLocalCoordinatorclassPaxosCleanupSessionclassPaxosFinishPrepareCleanupclassPaxosStartPrepareCleanupDetermines the highest ballot we should attempt to repair -
Uses of AbstractFuture in org.apache.cassandra.service.reads.repair
Subclasses of AbstractFuture in org.apache.cassandra.service.reads.repair Modifier and Type Class Description classBlockingPartitionRepair -
Uses of AbstractFuture in org.apache.cassandra.streaming
Subclasses of AbstractFuture in org.apache.cassandra.streaming Modifier and Type Class Description classStreamResultFutureA future on the result (StreamState) of a streaming plan. -
Uses of AbstractFuture in org.apache.cassandra.utils.concurrent
Subclasses of AbstractFuture in org.apache.cassandra.utils.concurrent Modifier and Type Class Description classAsyncFuture<V>Our defaultFutureimplementation, with all state being managed without locks (except those used by the JVM).classAsyncPromise<V>ExtendsAsyncFutureto implement thePromiseinterface.static classAsyncPromise.WithExecutor<V>classFutureCombiner<T>Netty's PromiseCombiner is not threadsafe, and we combine futures from multiple event executors.classImmediateFuture<V>classSyncFuture<V>Netty's DefaultPromise uses a mutex to coordinate notifiers AND waiters between the eventLoop and the other threads.classSyncPromise<V>ExtendsSyncFutureto implement thePromiseinterface.static classSyncPromise.WithExecutor<V>Methods in org.apache.cassandra.utils.concurrent that return AbstractFuture Modifier and Type Method Description AbstractFuture<V>AbstractFuture. addCallback(com.google.common.util.concurrent.FutureCallback<? super V> callback)SupportFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)natively SeeaddListener(GenericFutureListener)for ordering semantics.AbstractFuture<V>AbstractFuture. addCallback(com.google.common.util.concurrent.FutureCallback<? super V> callback, java.util.concurrent.Executor executor)SupportFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)natively SeeaddListener(GenericFutureListener)for ordering semantics.AbstractFuture<V>AbstractFuture. addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> callback)SupportFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)natively SeeaddListener(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 ofFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)SeeaddListener(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 ofFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)SeeaddListener(GenericFutureListener)for ordering semantics.Methods in org.apache.cassandra.utils.concurrent with parameters of type AbstractFuture Modifier and Type Method 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)SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)natively SeeaddListener(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)SupportFutures.transform(ListenableFuture, com.google.common.base.Function, Executor)natively SeeaddListener(GenericFutureListener)for ordering semantics.
-