Modifier and Type | Method and Description |
---|---|
Future<?> |
BatchlogManager.startBatchlogReplay() |
Modifier and Type | Method and Description |
---|---|
Future<Pair<K,V>> |
AutoSavingCache.CacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
Future<java.lang.Integer> |
AutoSavingCache.loadSavedAsync() |
Future<?> |
AutoSavingCache.submitWrite(int keysToSave) |
Modifier and Type | Method and Description |
---|---|
<T> Future<T> |
ExecutorPlus.submit(java.util.concurrent.Callable<T> task)
Overrides
ExecutorService.submit(Callable) to return a Cassandra Future |
<T> Future<T> |
ImmediateExecutor.submit(java.util.concurrent.Callable<T> task) |
<T> Future<T> |
SEPExecutor.submit(java.util.concurrent.Callable<T> call) |
<T> Future<T> |
ScheduledThreadPoolExecutorPlus.submit(java.util.concurrent.Callable<T> call) |
<T> Future<T> |
Stage.submit(java.util.concurrent.Callable<T> task) |
<T> Future<T> |
ThreadPoolExecutorPlus.submit(java.util.concurrent.Callable<T> call) |
<T> Future<T> |
WrappedExecutorPlus.submit(java.util.concurrent.Callable<T> task) |
Future<?> |
ExecutorPlus.submit(java.lang.Runnable task)
Overrides
ExecutorService.submit(Runnable) to return a Cassandra Future |
Future<?> |
ImmediateExecutor.submit(java.lang.Runnable task) |
Future<?> |
SEPExecutor.submit(java.lang.Runnable run) |
Future<?> |
ScheduledThreadPoolExecutorPlus.submit(java.lang.Runnable run) |
Future<?> |
Stage.submit(java.lang.Runnable task) |
Future<?> |
ThreadPoolExecutorPlus.submit(java.lang.Runnable run) |
Future<?> |
WrappedExecutorPlus.submit(java.lang.Runnable task) |
<T> Future<T> |
ExecutorPlus.submit(java.lang.Runnable task,
T result)
Overrides
ExecutorService.submit(Runnable, Object) to return a Cassandra Future |
<T> Future<T> |
ImmediateExecutor.submit(java.lang.Runnable task,
T result) |
<T> Future<T> |
SEPExecutor.submit(java.lang.Runnable run,
T result) |
<T> Future<T> |
ScheduledThreadPoolExecutorPlus.submit(java.lang.Runnable run,
T result) |
<T> Future<T> |
Stage.submit(java.lang.Runnable task,
T result) |
<T> Future<T> |
ThreadPoolExecutorPlus.submit(java.lang.Runnable run,
T result) |
<T> Future<T> |
WrappedExecutorPlus.submit(java.lang.Runnable task,
T result) |
<T> Future<T> |
ExecutorPlus.submit(WithResources withResources,
java.util.concurrent.Callable<T> task)
Invoke
task , returning a future representing this computation. |
<T> Future<T> |
ImmediateExecutor.submit(WithResources withResources,
java.util.concurrent.Callable<T> task) |
<T> Future<T> |
SEPExecutor.submit(WithResources withResources,
java.util.concurrent.Callable<T> call) |
<T> Future<T> |
ScheduledThreadPoolExecutorPlus.submit(WithResources withResources,
java.util.concurrent.Callable<T> call) |
<T> Future<T> |
ThreadPoolExecutorPlus.submit(WithResources withResources,
java.util.concurrent.Callable<T> call) |
<T> Future<T> |
WrappedExecutorPlus.submit(WithResources withResources,
java.util.concurrent.Callable<T> task) |
Future<?> |
ExecutorPlus.submit(WithResources withResources,
java.lang.Runnable task)
Invoke
task , returning a future yielding null if successful,
or the abnormal termination of task otherwise. |
Future<?> |
ImmediateExecutor.submit(WithResources withResources,
java.lang.Runnable task) |
Future<?> |
SEPExecutor.submit(WithResources withResources,
java.lang.Runnable run) |
Future<?> |
ScheduledThreadPoolExecutorPlus.submit(WithResources withResources,
java.lang.Runnable run) |
Future<?> |
ThreadPoolExecutorPlus.submit(WithResources withResources,
java.lang.Runnable run) |
Future<?> |
WrappedExecutorPlus.submit(WithResources withResources,
java.lang.Runnable task) |
<T> Future<T> |
ExecutorPlus.submit(WithResources withResources,
java.lang.Runnable task,
T result)
Invoke
task , returning a future yielding result if successful,
or the abnormal termination of task otherwise. |
<T> Future<T> |
ImmediateExecutor.submit(WithResources withResources,
java.lang.Runnable task,
T result) |
<T> Future<T> |
SEPExecutor.submit(WithResources withResources,
java.lang.Runnable run,
T result) |
<T> Future<T> |
ScheduledThreadPoolExecutorPlus.submit(WithResources withResources,
java.lang.Runnable run,
T result) |
<T> Future<T> |
ThreadPoolExecutorPlus.submit(WithResources withResources,
java.lang.Runnable run,
T result) |
<T> Future<T> |
WrappedExecutorPlus.submit(WithResources withResources,
java.lang.Runnable task,
T result) |
Modifier and Type | Method and Description |
---|---|
static Future<UntypedResultSet> |
QueryProcessor.executeAsync(InetAddressAndPort address,
java.lang.String query,
java.lang.Object... values) |
Modifier and Type | Method and Description |
---|---|
Future<?> |
Mutation.applyFuture() |
Future<?> |
Keyspace.applyFuture(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes) |
Future<?> |
Keyspace.applyFuture(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes,
boolean isDroppable,
boolean isDeferrable) |
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 memtables
|
Future<?> |
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 provided
|
Modifier and Type | Method and Description |
---|---|
java.util.List<Future<?>> |
Keyspace.flush(ColumnFamilyStore.FlushReason reason) |
Modifier and Type | Method and Description |
---|---|
protected Future<java.lang.Integer> |
CommitLogReplayer.MutationInitiator.initiateMutation(Mutation mutation,
long segmentId,
int serializedSize,
int entryLocation,
CommitLogReplayer commitLogReplayer) |
Modifier and Type | Method and 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 silo
|
Future<?> |
CompactionManager.submitUserDefined(ColumnFamilyStore cfs,
java.util.Collection<Descriptor> dataFiles,
int gcBefore) |
Future<?> |
CompactionManager.submitValidation(java.util.concurrent.Callable<java.lang.Object> validation) |
Future<java.lang.Long> |
CompactionManager.submitViewBuilder(ViewBuilderTask task) |
Modifier and Type | Method and 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,
int gcBefore,
boolean splitOutput) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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() |
Modifier and Type | Method and Description |
---|---|
Future<StreamState> |
BootStrapper.bootstrap(StreamStateStore stateStore,
boolean useStrictConsistency) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
Future<?> |
SecondaryIndexManager.addIndex(IndexMetadata indexDef,
boolean isNewCF)
Adds and builds a index
|
Modifier and Type | Method and Description |
---|---|
<T> Future<Message<T>> |
MessagingService.sendWithResult(Message message,
InetAddressAndPort to) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
default <T> Future<T> |
Scheduler.schedule(java.util.function.Supplier<Future<T>> task,
java.util.concurrent.Executor executor) |
Constructor and Description |
---|
Task(java.util.function.Supplier<Future<T>> supplier) |
Modifier and Type | Method and 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() |
Modifier and Type | Method and Description |
---|---|
Future<CoordinatedRepairResult> |
CoordinatorSession.execute(java.util.function.Supplier<Future<CoordinatedRepairResult>> sessionSubmitter)
Runs the asynchronous consistent repair session.
|
Modifier and Type | Method and Description |
---|---|
Future<?> |
StorageService.autoRepairPaxos(TableId tableId) |
Future<Pair<CounterCacheKey,ClockAndCount>> |
CacheService.CounterCacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
Future<Pair<RowCacheKey,IRowCacheEntry>> |
CacheService.RowCacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
Future<Pair<KeyCacheKey,RowIndexEntry>> |
CacheService.KeyCacheSerializer.deserialize(DataInputPlus input,
ColumnFamilyStore cfs) |
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) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
Future<?> |
NettyStreamingChannel.send(StreamingChannel.Send send) |
Modifier and Type | Method and Description |
---|---|
static <T> Future<java.util.List<T>> |
FBUtilities.allOf(java.util.Collection<? extends Future<? extends T>> futures)
Returns a new
Future wrapping the given list of futures and returning a list of their results. |
Modifier and Type | Method and Description |
---|---|
static <T> Future<java.util.List<T>> |
FBUtilities.allOf(java.util.Collection<? extends Future<? extends T>> futures)
Returns a new
Future wrapping the given list of futures and returning a list of their results. |
Modifier and Type | Interface and Description |
---|---|
interface |
Promise<V>
A Promise that integrates
Promise with our Future API
to improve clarity and coherence in the codebase. |
interface |
RunnableFuture<V> |
Modifier and Type | Method and Description |
---|---|
Future<V> |
Future.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 |
Future<V> |
AbstractFuture.addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> callback,
java.util.concurrent.Executor executor) |
Future<V> |
Future.addCallback(java.util.function.BiConsumer<? super V,java.lang.Throwable> 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 |
Future<V> |
Future.addCallback(java.util.function.Consumer<? super V> onSuccess,
java.util.function.Consumer<? super java.lang.Throwable> onFailure)
Support
Futures.addCallback(com.google.common.util.concurrent.ListenableFuture<V>, com.google.common.util.concurrent.FutureCallback<? super V>, java.util.concurrent.Executor) natively |
Future<V> |
Future.addCallback(java.util.function.Consumer<? super V> onSuccess,
java.util.function.Consumer<? super java.lang.Throwable> onFailure,
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 |
Future<V> |
Future.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 |
Future<V> |
Future.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 |
Future<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 interrupt
|
Future<V> |
SyncFuture.await() |
Future<V> |
AbstractFuture.awaitThrowUncheckedOnInterrupt()
Wait for this future to complete
Awaitable.awaitThrowUncheckedOnInterrupt() |
Future<V> |
Future.awaitThrowUncheckedOnInterrupt()
Wait indefinitely for this promise to complete, throwing any interrupt as an UncheckedInterruptedException
|
Future<V> |
AbstractFuture.awaitUninterruptibly()
Wait for this future to complete
Awaitable.awaitUninterruptibly() |
Future<V> |
Future.awaitUninterruptibly()
Wait indefinitely for this future to complete
|
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 AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
default <T> Future<T> |
Future.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively |
<T> Future<T> |
AsyncFuture.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper,
java.util.concurrent.Executor executor)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
<T> Future<T> |
Future.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper,
java.util.concurrent.Executor executor)
Support
Futures.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)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See AbstractFuture.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 AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
<T> Future<T> |
AbstractFuture.map(java.util.function.Function<? super V,? extends T> mapper)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
default <T> Future<T> |
Future.map(java.util.function.Function<? super V,? extends T> mapper)
Support
Futures.transform(ListenableFuture, com.google.common.base.Function, Executor) natively |
<T> Future<T> |
AsyncFuture.map(java.util.function.Function<? super V,? extends T> mapper,
java.util.concurrent.Executor executor)
Support
Futures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor) natively
See AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
<T> Future<T> |
Future.map(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 |
<T> Future<T> |
SyncFuture.map(java.util.function.Function<? super V,? extends T> mapper,
java.util.concurrent.Executor executor)
Support
Futures.transform(com.google.common.util.concurrent.ListenableFuture<I>, com.google.common.base.Function<? super I, ? extends O>, java.util.concurrent.Executor) natively
See AbstractFuture.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 traces
|
default 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 traces
|
default 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 traces
|
Modifier and Type | Method and Description |
---|---|
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) |
static <V> io.netty.util.concurrent.GenericFutureListener<? extends Future<V>> |
Promise.listener(com.google.common.util.concurrent.FutureCallback<V> callback) |
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 AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
default <T> Future<T> |
Future.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively |
<T> Future<T> |
AsyncFuture.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper,
java.util.concurrent.Executor executor)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
<T> Future<T> |
Future.flatMap(java.util.function.Function<? super V,? extends Future<T>> flatMapper,
java.util.concurrent.Executor executor)
Support
Futures.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)
Support
Futures.transformAsync(ListenableFuture, AsyncFunction, Executor) natively
See AbstractFuture.addListener(GenericFutureListener) for ordering semantics. |
Modifier and Type | Method and Description |
---|---|
Future<java.lang.Boolean> |
MemtableCleaner.clean()
This is a function that schedules a cleaning task, normally flushing of the largest sstable.
|
Copyright © 2009- The Apache Software Foundation