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 | Method and Description |
---|---|
Awaitable |
DefaultSchemaUpdateHandler.clear()
When clear is called the update handler will flag that the clear was requested.
|
Awaitable |
OfflineSchemaUpdateHandler.clear() |
Awaitable |
SchemaUpdateHandler.clear()
Marks the local schema to be cleared and refreshed.
|
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 | Interface and Description |
---|---|
interface |
Condition
Simpler API than java.util.concurrent.Condition; would be nice to extend it, but also nice
to share API with Future, for which Netty's API is incompatible with java.util.concurrent.Condition
Awaitable for explicit external signals. |
interface |
ConditionAsConsumer<T> |
interface |
CountDownLatch |
interface |
Future<V>
A Future that integrates several different (but equivalent) APIs used within Cassandra into a single concept,
integrating also with our
Awaitable abstraction, to overall improve coherency and clarity in the codebase. |
interface |
Promise<V>
A Promise that integrates
Promise with our Future API
to improve clarity and coherence in the codebase. |
interface |
RunnableFuture<V> |
static interface |
WaitQueue.Signal
A Signal is a one-time-use mechanism for a thread to wait for notification that some condition
state has transitioned that it may be interested in (and hence should check if it is).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractFuture<V>
Our default
Future implementation, with all state being managed without locks (except those used by the JVM). |
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> |
static class |
Awaitable.AbstractAwaitable |
static class |
Awaitable.AsyncAwaitable
A barebones asynchronous
Awaitable . |
static class |
Awaitable.SyncAwaitable
A barebones
Awaitable that uses mutual exclusion. |
static class |
Condition.Async
An asynchronous
Condition . |
static class |
Condition.Sync
A
Condition based on its object monitor. |
static class |
ConditionAsConsumer.Async<T> |
static class |
CountDownLatch.Async |
static class |
CountDownLatch.Sync |
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> |
static class |
WaitQueue.Standard.AbstractSignal
An abstract signal implementation
TODO: use intrusive linked list
|
Modifier and Type | Method and Description |
---|---|
static <A extends Awaitable> |
Awaitable.Defaults.awaitThrowUncheckedOnInterrupt(A await) |
static <A extends Awaitable> |
Awaitable.Defaults.awaitUninterruptibly(A await)
|
Modifier and Type | Method and Description |
---|---|
Awaitable |
Awaitable.await()
Await indefinitely, throwing any interrupt.
|
Awaitable |
Awaitable.AsyncAwaitable.await()
|
Awaitable |
Awaitable.SyncAwaitable.await()
|
Awaitable |
Awaitable.awaitThrowUncheckedOnInterrupt()
Await indefinitely, throwing any interrupt as an unchecked exception.
|
Awaitable |
Awaitable.AbstractAwaitable.awaitThrowUncheckedOnInterrupt()
|
Awaitable |
Awaitable.awaitUninterruptibly()
Await indefinitely, ignoring interrupts (but maintaining the interrupt flag on exit).
|
Awaitable |
Awaitable.AbstractAwaitable.awaitUninterruptibly()
|
Modifier and Type | Method and Description |
---|---|
static boolean |
Awaitable.Defaults.await(Awaitable await,
long time,
java.util.concurrent.TimeUnit unit) |
static boolean |
Awaitable.Defaults.awaitThrowUncheckedOnInterrupt(Awaitable await,
long time,
java.util.concurrent.TimeUnit units) |
static boolean |
Awaitable.Defaults.awaitUninterruptibly(Awaitable await,
long time,
java.util.concurrent.TimeUnit units) |
static boolean |
Awaitable.Defaults.awaitUntilThrowUncheckedOnInterrupt(Awaitable await,
long nanoTimeDeadline) |
static boolean |
Awaitable.Defaults.awaitUntilUninterruptibly(Awaitable await,
long nanoTimeDeadline)
|
Copyright © 2009-2022 The Apache Software Foundation