Package | Description |
---|---|
org.apache.cassandra.exceptions | |
org.apache.cassandra.index.sasi.plan | |
org.apache.cassandra.service | |
org.apache.cassandra.service.paxos |
Modifier and Type | Class and Description |
---|---|
class |
CasWriteTimeoutException |
class |
ReadTimeoutException |
class |
WriteTimeoutException |
Modifier and Type | Method and Description |
---|---|
UnfilteredPartitionIterator |
QueryPlan.execute(ReadExecutionController executionController) |
Modifier and Type | Method and Description |
---|---|
static RowIterator |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
DecoratedKey key,
CASRequest request,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit,
ClientState clientState,
int nowInSeconds,
long queryStartNanoTime)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
static RowIterator |
StorageProxy.legacyCas(java.lang.String keyspaceName,
java.lang.String cfName,
DecoratedKey key,
CASRequest request,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit,
ClientState clientState,
int nowInSeconds,
long queryStartNanoTime) |
Modifier and Type | Method and Description |
---|---|
static RowIterator |
Paxos.cas(DecoratedKey key,
CASRequest request,
ConsistencyLevel consistencyForConsensus,
ConsistencyLevel consistencyForCommit,
ClientState clientState)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
static RowIterator |
Paxos.cas(DecoratedKey key,
CASRequest request,
ConsistencyLevel consistencyForConsensus,
ConsistencyLevel consistencyForCommit,
ClientState clientState,
long proposeDeadline,
long commitDeadline) |
static PaxosOperationLock |
PaxosState.lock(DecoratedKey partitionKey,
TableMetadata metadata,
long deadline,
ConsistencyLevel consistencyForConsensus,
boolean isWrite) |
Copyright © 2009- The Apache Software Foundation