Uses of Interface
org.apache.cassandra.utils.concurrent.Future
-
-
Uses of Future in org.apache.cassandra.batchlog
Methods in org.apache.cassandra.batchlog that return Future Modifier and Type Method Description Future<?>
BatchlogManager. startBatchlogReplay()
-
Uses of Future in org.apache.cassandra.cache
Methods in org.apache.cassandra.cache that return Future Modifier and Type Method Description abstract Future<Pair<K,V>>
AutoSavingCache.CacheSerializer. deserialize(DataInputPlus in)
Future<java.lang.Integer>
AutoSavingCache. loadSavedAsync()
Future<?>
AutoSavingCache. submitWrite(int keysToSave)
-
Uses of Future in org.apache.cassandra.concurrent
Classes in org.apache.cassandra.concurrent that implement Future 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
.class
SyncFutureTask<T>
Methods in org.apache.cassandra.concurrent that return Future Modifier and Type Method Description Future<?>
ExecutorPlus. submit(java.lang.Runnable task)
OverridesExecutorService.submit(Runnable)
to return a CassandraFuture
<T> Future<T>
ExecutorPlus. submit(java.lang.Runnable task, T result)
OverridesExecutorService.submit(Runnable, Object)
to return a CassandraFuture
<T> Future<T>
ExecutorPlus. submit(java.util.concurrent.Callable<T> task)
OverridesExecutorService.submit(Callable)
to return a CassandraFuture
Future<?>
ExecutorPlus. submit(WithResources withResources, java.lang.Runnable task)
Invoketask
, returning a future yieldingnull
if successful, or the abnormal termination oftask
otherwise.<T> Future<T>
ExecutorPlus. submit(WithResources withResources, java.lang.Runnable task, T result)
Invoketask
, returning a future yieldingresult
if successful, or the abnormal termination oftask
otherwise.<T> Future<T>
ExecutorPlus. submit(WithResources withResources, java.util.concurrent.Callable<T> task)
Invoketask
, returning a future representing this computation.Future<?>
ImmediateExecutor. submit(java.lang.Runnable task)
<T> Future<T>
ImmediateExecutor. submit(java.lang.Runnable task, T result)
<T> Future<T>
ImmediateExecutor. submit(java.util.concurrent.Callable<T> task)
Future<?>
ImmediateExecutor. submit(WithResources withResources, java.lang.Runnable task)
<T> Future<T>
ImmediateExecutor. submit(WithResources withResources, java.lang.Runnable task, T result)
<T> Future<T>
ImmediateExecutor. submit(WithResources withResources, java.util.concurrent.Callable<T> task)
Future<?>
ScheduledThreadPoolExecutorPlus. submit(java.lang.Runnable run)
<T> Future<T>
ScheduledThreadPoolExecutorPlus. submit(java.lang.Runnable run, T result)
<T> Future<T>
ScheduledThreadPoolExecutorPlus. submit(java.util.concurrent.Callable<T> call)
Future<?>
ScheduledThreadPoolExecutorPlus. submit(WithResources withResources, java.lang.Runnable run)
<T> Future<T>
ScheduledThreadPoolExecutorPlus. submit(WithResources withResources, java.lang.Runnable run, T result)
<T> Future<T>
ScheduledThreadPoolExecutorPlus. submit(WithResources withResources, java.util.concurrent.Callable<T> call)
Future<?>
SEPExecutor. submit(java.lang.Runnable run)
<T> Future<T>
SEPExecutor. submit(java.lang.Runnable run, T result)
<T> Future<T>
SEPExecutor. submit(java.util.concurrent.Callable<T> call)
Future<?>
SEPExecutor. submit(WithResources withResources, java.lang.Runnable run)
<T> Future<T>
SEPExecutor. submit(WithResources withResources, java.lang.Runnable run, T result)
<T> Future<T>
SEPExecutor. submit(WithResources withResources, java.util.concurrent.Callable<T> call)
Future<?>
Stage. submit(java.lang.Runnable task)
<T> Future<T>
Stage. submit(java.lang.Runnable task, T result)
<T> Future<T>
Stage. submit(java.util.concurrent.Callable<T> task)
Future<?>
ThreadPoolExecutorPlus. submit(java.lang.Runnable run)
<T> Future<T>
ThreadPoolExecutorPlus. submit(java.lang.Runnable run, T result)
<T> Future<T>
ThreadPoolExecutorPlus. submit(java.util.concurrent.Callable<T> call)
Future<?>
ThreadPoolExecutorPlus. submit(WithResources withResources, java.lang.Runnable run)
<T> Future<T>
ThreadPoolExecutorPlus. submit(WithResources withResources, java.lang.Runnable run, T result)
<T> Future<T>
ThreadPoolExecutorPlus. submit(WithResources withResources, java.util.concurrent.Callable<T> call)
Future<?>
WrappedExecutorPlus. submit(java.lang.Runnable task)
<T> Future<T>
WrappedExecutorPlus. submit(java.lang.Runnable task, T result)
<T> Future<T>
WrappedExecutorPlus. submit(java.util.concurrent.Callable<T> task)
Future<?>
WrappedExecutorPlus. submit(WithResources withResources, java.lang.Runnable task)
<T> Future<T>
WrappedExecutorPlus. submit(WithResources withResources, java.lang.Runnable task, T result)
<T> Future<T>
WrappedExecutorPlus. submit(WithResources withResources, java.util.concurrent.Callable<T> task)
-
Uses of Future in org.apache.cassandra.cql3
Methods in org.apache.cassandra.cql3 that return Future Modifier and Type Method Description static Future<UntypedResultSet>
QueryProcessor. executeAsync(InetAddressAndPort address, java.lang.String query, java.lang.Object... values)
-
Uses of Future in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return Future Modifier and Type Method Description Future<?>
Keyspace. applyFuture(Mutation mutation, boolean writeCommitLog, boolean updateIndexes)
Future<?>
Keyspace. applyFuture(Mutation mutation, boolean writeCommitLog, boolean updateIndexes, boolean isDroppable, boolean isDeferrable)
Future<?>
Mutation. applyFuture()
Future<CommitLogPosition>
ColumnFamilyStore. dumpMemtable()
Drops current memtable without flushing to disk.Future<CommitLogPosition>
ColumnFamilyStore. forceFlush(ColumnFamilyStore.FlushReason reason)
Flush if there is unflushed data in the memtablesFuture<?>
ColumnFamilyStore. forceFlush(CommitLogPosition flushIfDirtyBefore)
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore (inclusive).Future<CommitLogPosition>
ColumnFamilyStore. signalFlushRequired(Memtable memtable, ColumnFamilyStore.FlushReason reason)
Future<CommitLogPosition>
ColumnFamilyStore. switchMemtable(ColumnFamilyStore.FlushReason reason)
Future<CommitLogPosition>
ColumnFamilyStore. switchMemtableIfCurrent(Memtable memtable, ColumnFamilyStore.FlushReason reason)
Switches the memtable iff the live memtable is the one providedMethods in org.apache.cassandra.db that return types with arguments of type Future Modifier and Type Method Description java.util.List<Future<?>>
Keyspace. flush(ColumnFamilyStore.FlushReason reason)
-
Uses of Future in org.apache.cassandra.db.commitlog
Methods in org.apache.cassandra.db.commitlog that return Future Modifier and Type Method Description protected Future<java.lang.Integer>
CommitLogReplayer.MutationInitiator. initiateMutation(Mutation mutation, long segmentId, int serializedSize, int entryLocation, CommitLogReplayer commitLogReplayer)
-
Uses of Future in org.apache.cassandra.db.compaction
Methods in org.apache.cassandra.db.compaction that return Future Modifier and Type Method Description Future<?>
CompactionManager. submitCacheWrite(AutoSavingCache.Writer writer)
Future<?>
CompactionManager. submitIndexBuild(SecondaryIndexBuilder builder)
Is not scheduled, because it is performing disjoint work from sstable compaction.Future<java.lang.Void>
CompactionManager. submitPendingAntiCompaction(ColumnFamilyStore cfs, RangesAtEndpoint tokenRanges, Refs<SSTableReader> sstables, LifecycleTransaction txn, TimeUUID sessionId, java.util.function.BooleanSupplier isCancelled)
Splits the given token ranges of the given sstables into a pending repair siloFuture<?>
CompactionManager. submitUserDefined(ColumnFamilyStore cfs, java.util.Collection<Descriptor> dataFiles, long gcBefore)
Future<?>
CompactionManager. submitValidation(java.util.concurrent.Callable<java.lang.Object> validation)
Future<java.lang.Long>
CompactionManager. submitViewBuilder(ViewBuilderTask task)
Methods in org.apache.cassandra.db.compaction that return types with arguments of type Future Modifier and Type Method Description java.util.List<Future<?>>
CompactionManager. submitBackground(ColumnFamilyStore cfs)
Call this whenever a compaction might be needed on the given columnfamily.java.util.List<Future<?>>
CompactionManager. submitMaximal(ColumnFamilyStore cfStore, long gcBefore, boolean splitOutput)
java.util.List<Future<?>>
CompactionManager. submitMaximal(ColumnFamilyStore cfStore, long gcBefore, boolean splitOutput, OperationType operationType)
-
Uses of Future in org.apache.cassandra.db.memtable
Methods in org.apache.cassandra.db.memtable that return Future Modifier and Type Method Description static Future<java.lang.Boolean>
AbstractAllocatorMemtable. flushLargestMemtable()
Finds the largest memtable, as a percentage of *either* on- or off-heap memory limits, and immediately queues it for flushing.Future<CommitLogPosition>
Memtable.Owner. signalFlushRequired(Memtable memtable, ColumnFamilyStore.FlushReason reason)
Signal to the owner that a flush is required (e.g. -
Uses of Future in org.apache.cassandra.db.repair
Methods in org.apache.cassandra.db.repair that return Future Modifier and Type Method Description Future<java.util.List<java.lang.Void>>
CassandraKeyspaceRepairManager. prepareIncrementalRepair(TimeUUID sessionID, java.util.Collection<ColumnFamilyStore> tables, RangesAtEndpoint tokenRanges, java.util.concurrent.ExecutorService executor, java.util.function.BooleanSupplier isCancelled)
Future<java.util.List<java.lang.Void>>
PendingAntiCompaction. run()
-
Uses of Future in org.apache.cassandra.dht
Methods in org.apache.cassandra.dht that return Future Modifier and Type Method Description Future<StreamState>
BootStrapper. bootstrap(StreamStateStore stateStore, boolean useStrictConsistency)
-
Uses of Future in org.apache.cassandra.hints
Methods in org.apache.cassandra.hints that return Future Modifier and Type Method Description Future
HintsService. transferHints(java.util.function.Supplier<java.util.UUID> hostIdSupplier)
Transfer all local hints to the hostId supplied by hostIdSupplier Flushes the buffer to make sure all hints are on disk and closes the hint writers so we don't leave any hint files around. -
Uses of Future in org.apache.cassandra.index
Methods in org.apache.cassandra.index that return Future Modifier and Type Method Description Future<?>
SecondaryIndexManager. addIndex(IndexMetadata indexDef, boolean isNewCF)
Adds and builds a indexFuture<java.lang.Void>
SecondaryIndexManager. buildIndex(Index index)
-
Uses of Future in org.apache.cassandra.net
Classes in org.apache.cassandra.net that implement Future 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.Methods in org.apache.cassandra.net that return Future Modifier and Type Method Description <REQ,RSP>
Future<Message<RSP>>MessageDelivery. sendWithResult(Message<REQ> message, InetAddressAndPort to)
<REQ,RSP>
Future<Message<RSP>>MessagingService. sendWithResult(Message<REQ> message, InetAddressAndPort to)
-
Uses of Future in org.apache.cassandra.repair
Classes in org.apache.cassandra.repair that implement Future 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.Methods in org.apache.cassandra.repair that return Future Modifier and Type Method Description default Future<CoordinatedRepairResult>
RepairTask. perform(ExecutorPlus executor, Scheduler validationScheduler)
Future<CoordinatedRepairResult>
IncrementalRepairTask. performUnsafe(ExecutorPlus executor, Scheduler validationScheduler)
Future<CoordinatedRepairResult>
NormalRepairTask. performUnsafe(ExecutorPlus executor, Scheduler validationScheduler)
Future<CoordinatedRepairResult>
PreviewRepairTask. performUnsafe(ExecutorPlus executor, Scheduler validationScheduler)
Future<CoordinatedRepairResult>
RepairTask. performUnsafe(ExecutorPlus executor, Scheduler validationScheduler)
Future<java.util.List<java.lang.Void>>
KeyspaceRepairManager. prepareIncrementalRepair(TimeUUID sessionID, java.util.Collection<ColumnFamilyStore> tables, RangesAtEndpoint tokenRanges, java.util.concurrent.ExecutorService executor, java.util.function.BooleanSupplier isCancelled)
Isolate the unrepaired ranges of the given tables, and make referenceable by session id.protected Future<CoordinatedRepairResult>
AbstractRepairTask. runRepair(TimeUUID parentSession, boolean isIncremental, ExecutorPlus executor, Scheduler validationScheduler, java.util.List<CommonRange> commonRanges, java.lang.String... cfnames)
default <T> Future<T>
Scheduler. schedule(java.util.function.Supplier<Future<T>> task, java.util.concurrent.Executor executor)
Method parameters in org.apache.cassandra.repair with type arguments of type Future Modifier and Type Method Description default <T> Future<T>
Scheduler. schedule(java.util.function.Supplier<Future<T>> task, java.util.concurrent.Executor executor)
Constructor parameters in org.apache.cassandra.repair with type arguments of type Future Constructor Description Task(java.util.function.Supplier<Future<T>> supplier)
-
Uses of Future in org.apache.cassandra.repair.consistent
Methods in org.apache.cassandra.repair.consistent that return Future Modifier and Type Method Description Future<CoordinatedRepairResult>
CoordinatorSession. execute(java.util.function.Supplier<Future<CoordinatedRepairResult>> sessionSubmitter)
Runs the asynchronous consistent repair session.Future<java.lang.Void>
CoordinatorSession. finalizePropose()
Future<java.lang.Void>
CoordinatorSession. prepare()
Method parameters in org.apache.cassandra.repair.consistent with type arguments of type Future Modifier and Type Method Description Future<CoordinatedRepairResult>
CoordinatorSession. execute(java.util.function.Supplier<Future<CoordinatedRepairResult>> sessionSubmitter)
Runs the asynchronous consistent repair session. -
Uses of Future in org.apache.cassandra.repair.messages
Methods in org.apache.cassandra.repair.messages with parameters of type Future Modifier and Type Method Description static java.util.function.Supplier<java.lang.Boolean>
RepairMessage. notDone(Future<?> f)
-
Uses of Future in org.apache.cassandra.service
Methods in org.apache.cassandra.service that return Future Modifier and Type Method Description Future<?>
StorageService. autoRepairPaxos(TableId tableId)
Future<Pair<CounterCacheKey,ClockAndCount>>
CacheService.CounterCacheSerializer. deserialize(DataInputPlus in)
Future<Pair<KeyCacheKey,AbstractRowIndexEntry>>
CacheService.KeyCacheSerializer. deserialize(DataInputPlus input)
Future<Pair<RowCacheKey,IRowCacheEntry>>
CacheService.RowCacheSerializer. deserialize(DataInputPlus in)
Future<?>
ActiveRepairService. prepareForRepair(TimeUUID parentRepairSession, InetAddressAndPort coordinator, java.util.Set<InetAddressAndPort> endpoints, RepairOption options, boolean isForcedRepair, java.util.List<ColumnFamilyStore> columnFamilyStores)
Future<?>
ActiveRepairService. repairPaxosForTopologyChange(java.lang.String ksName, java.util.Collection<Range<Token>> ranges, java.lang.String reason)
Future<StreamState>
StorageService. startBootstrap(java.util.Collection<Token> tokens)
Future<StreamState>
StorageService. startBootstrap(java.util.Collection<Token> tokens, boolean replacing)
Future<?>
StorageService. startRepairPaxosForTopologyChange(java.lang.String reason)
Methods in org.apache.cassandra.service that return types with arguments of type Future Modifier and Type Method Description java.util.function.Supplier<Future<StreamState>>
StorageService. prepareUnbootstrapStreaming()
Pair<java.lang.Integer,Future<?>>
StorageService. repair(java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> repairSpec, java.util.List<ProgressListener> listeners)
Pair<java.lang.Integer,Future<?>>
StorageService. repair(java.lang.String keyspace, RepairOption option, java.util.List<ProgressListener> listeners)
-
Uses of Future in org.apache.cassandra.service.paxos.cleanup
Classes in org.apache.cassandra.service.paxos.cleanup that implement Future 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 Future in org.apache.cassandra.service.reads.repair
Classes in org.apache.cassandra.service.reads.repair that implement Future Modifier and Type Class Description class
BlockingPartitionRepair
-
Uses of Future in org.apache.cassandra.streaming
Classes in org.apache.cassandra.streaming that implement Future Modifier and Type Class Description class
StreamResultFuture
A future on the result (StreamState
) of a streaming plan. -
Uses of Future in org.apache.cassandra.streaming.async
Methods in org.apache.cassandra.streaming.async that return Future Modifier and Type Method Description Future<?>
NettyStreamingChannel. send(StreamingChannel.Send send)
-
Uses of Future in org.apache.cassandra.utils
Methods in org.apache.cassandra.utils that return Future Modifier and Type Method Description static <T> Future<java.util.List<T>>
FBUtilities. allOf(java.util.Collection<? extends Future<? extends T>> futures)
Returns a newFuture
wrapping the given list of futures and returning a list of their results.Method parameters in org.apache.cassandra.utils with type arguments of type Future Modifier and Type Method Description static <T> Future<java.util.List<T>>
FBUtilities. allOf(java.util.Collection<? extends Future<? extends T>> futures)
Returns a newFuture
wrapping the given list of futures and returning a list of their results. -
Uses of Future in org.apache.cassandra.utils.concurrent
Subinterfaces of Future in org.apache.cassandra.utils.concurrent Modifier and Type Interface Description interface
Promise<V>
A Promise that integratesPromise
with ourFuture
API to improve clarity and coherence in the codebase.interface
RunnableFuture<V>
Classes in org.apache.cassandra.utils.concurrent that implement Future Modifier and Type Class Description class
AbstractFuture<V>
Our defaultFuture
implementation, with all state being managed without locks (except those used by the JVM).class
AsyncFuture<V>
Our defaultFuture
implementation, with all state being managed without locks (except those used by the JVM).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>
class
SyncFuture<V>
Netty's DefaultPromise uses a mutex to coordinate notifiers AND waiters between the eventLoop and the other threads.class
SyncPromise<V>
ExtendsSyncFuture
to implement thePromise
interface.static class
SyncPromise.WithExecutor<V>
Methods in org.apache.cassandra.utils.concurrent that return Future Modifier and Type Method Description Future<V>
AbstractFuture. addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> callback, java.util.concurrent.Executor executor)
Future<V>
Future. 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)
nativelyFuture<V>
Future. 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)
nativelyFuture<V>
Future. 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)
nativelyFuture<V>
Future. addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> 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)
nativelyFuture<V>
Future. addCallback(java.util.function.Consumer<? super V> onSuccess, java.util.function.Consumer<? super java.lang.Throwable> onFailure)
SupportFutures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor)
nativelyFuture<V>
Future. addCallback(java.util.function.Consumer<? super V> onSuccess, java.util.function.Consumer<? super java.lang.Throwable> onFailure, 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)
nativelyFuture<V>
AbstractFuture. addListener(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>> listener)
Add a listener to be invoked once this future completes.Future<V>
Future. addListener(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>> genericFutureListener)
Future<V>
AbstractFuture. addListeners(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>>... listeners)
Future<V>
Future. addListeners(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>>... genericFutureListeners)
static <V> Future<java.util.List<V>>
FutureCombiner. allOf(java.util.Collection<? extends io.netty.util.concurrent.Future<? extends V>> futures)
Waits only until the first failure, or until all have succeeded.Future<V>
Future. await()
Wait indefinitely for this future to complete, throwing any interruptFuture<V>
SyncFuture. await()
Future<V>
AbstractFuture. awaitThrowUncheckedOnInterrupt()
Wait for this future to completeAwaitable.awaitThrowUncheckedOnInterrupt()
Future<V>
Future. awaitThrowUncheckedOnInterrupt()
Wait indefinitely for this promise to complete, throwing any interrupt as an UncheckedInterruptedExceptionFuture<V>
AbstractFuture. awaitUninterruptibly()
Wait for this future to completeAwaitable.awaitUninterruptibly()
Future<V>
Future. awaitUninterruptibly()
Wait indefinitely for this future to completeprotected <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 SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.<T> Future<T>
AsyncFuture. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.default <T> Future<T>
Future. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively<T> Future<T>
Future. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively<T> Future<T>
SyncFuture. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.<T> Future<T>
AbstractFuture. map(java.util.function.Function<? super V,? extends T> mapper)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.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)
SupportFutures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.<T> Future<T>
AsyncFuture. map(java.util.function.Function<? super V,? extends T> mapper, java.util.concurrent.Executor executor)
SupportFutures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.default <T> Future<T>
Future. map(java.util.function.Function<? super V,? extends T> mapper)
SupportFutures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively<T> Future<T>
Future. map(java.util.function.Function<? super V,? extends T> mapper, java.util.concurrent.Executor executor)
SupportFutures.transform(ListenableFuture, com.google.common.base.Function, Executor)
natively<T> Future<T>
SyncFuture. map(java.util.function.Function<? super V,? extends T> mapper, java.util.concurrent.Executor executor)
SupportFutures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.Future<V>
AbstractFuture. removeListener(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>> listener)
Future<V>
Future. removeListener(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>> genericFutureListener)
Future<V>
AbstractFuture. removeListeners(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>>... listeners)
Future<V>
Future. removeListeners(io.netty.util.concurrent.GenericFutureListener<? extends io.netty.util.concurrent.Future<? super V>>... genericFutureListeners)
static <V> Future<java.util.List<V>>
FutureCombiner. successfulOf(java.util.List<? extends io.netty.util.concurrent.Future<V>> futures)
Waits for all futures to complete, returning a list containing values of all successful input futures.default Future<V>
Future. sync()
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack tracesdefault Future<V>
Future. syncThrowUncheckedOnInterrupt()
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack tracesdefault Future<V>
Future. syncUninterruptibly()
waits for completion; in case of failure rethrows the original exception without a new wrapping exception so may cause problems for reporting stack tracesMethods in org.apache.cassandra.utils.concurrent that return types with arguments of type Future Modifier and Type Method Description static <V> io.netty.util.concurrent.GenericFutureListener<? extends Future<V>>
Promise. listener(com.google.common.util.concurrent.FutureCallback<V> callback)
static <V> io.netty.util.concurrent.GenericFutureListener<? extends Future<V>>
Promise. listener(java.util.concurrent.ExecutorService executor, com.google.common.util.concurrent.FutureCallback<V> callback)
Method parameters in org.apache.cassandra.utils.concurrent with type arguments of type Future 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 SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.<T> Future<T>
AsyncFuture. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics.default <T> Future<T>
Future. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively<T> Future<T>
Future. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively<T> Future<T>
SyncFuture. flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper, java.util.concurrent.Executor executor)
SupportFutures.transformAsync(ListenableFuture, AsyncFunction, Executor)
natively SeeAbstractFuture.addListener(GenericFutureListener)
for ordering semantics. -
Uses of Future in org.apache.cassandra.utils.memory
Methods in org.apache.cassandra.utils.memory that return Future Modifier and Type Method Description Future<java.lang.Boolean>
MemtableCleaner. clean()
This is a function that schedules a cleaning task, normally flushing of the largest sstable.
-