Package | Description |
---|---|
org.apache.cassandra.db | |
org.apache.cassandra.service | |
org.apache.cassandra.thrift |
Modifier and Type | Method and Description |
---|---|
void |
ConsistencyLevel.assureSufficientLiveNodes(Keyspace keyspace,
java.lang.Iterable<java.net.InetAddress> liveEndpoints) |
Modifier and Type | Method and Description |
---|---|
static AbstractWriteResponseHandler |
StorageProxy.applyCounterMutationOnCoordinator(CounterMutation cm,
java.lang.String localDataCenter) |
static AbstractWriteResponseHandler |
StorageProxy.applyCounterMutationOnLeader(CounterMutation cm,
java.lang.String localDataCenter,
java.lang.Runnable callback) |
void |
AbstractWriteResponseHandler.assureSufficientLiveNodes() |
void |
ReadCallback.assureSufficientLiveNodes() |
static ColumnFamily |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
java.nio.ByteBuffer key,
CASRequest request,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit,
ClientState state)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
static java.util.List<Row> |
StorageProxy.getRangeSlice(AbstractRangeCommand command,
ConsistencyLevel consistency_level) |
static AbstractReadExecutor |
AbstractReadExecutor.getReadExecutor(ReadCommand command,
ConsistencyLevel consistencyLevel) |
static void |
StorageProxy.mutate(java.util.Collection<? extends IMutation> mutations,
ConsistencyLevel consistency_level)
Use this method to have these Mutations applied
across all replicas.
|
static void |
StorageProxy.mutateAtomically(java.util.Collection<Mutation> mutations,
ConsistencyLevel consistency_level)
See mutate.
|
static AbstractWriteResponseHandler |
StorageProxy.mutateCounter(CounterMutation cm,
java.lang.String localDataCenter)
Handle counter mutation on the coordinator host.
|
static void |
StorageProxy.mutateWithTriggers(java.util.Collection<? extends IMutation> mutations,
ConsistencyLevel consistencyLevel,
boolean mutateAtomically) |
static AbstractWriteResponseHandler |
StorageProxy.performWrite(IMutation mutation,
ConsistencyLevel consistency_level,
java.lang.String localDataCenter,
StorageProxy.WritePerformer performer,
java.lang.Runnable callback,
WriteType writeType)
Perform the write of a mutation given a WritePerformer.
|
static java.util.List<Row> |
StorageProxy.read(java.util.List<ReadCommand> commands,
ConsistencyLevel consistencyLevel) |
static java.util.List<Row> |
StorageProxy.read(java.util.List<ReadCommand> commands,
ConsistencyLevel consistencyLevel,
ClientState state)
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
|
static void |
StorageProxy.truncateBlocking(java.lang.String keyspace,
java.lang.String cfname)
Performs the truncate operatoin, which effectively deletes all data from
the column family cfname
|
Modifier and Type | Method and Description |
---|---|
static org.apache.cassandra.thrift.UnavailableException |
ThriftConversion.toThrift(UnavailableException e) |
Copyright © 2017 The Apache Software Foundation