Uses of Class
org.apache.cassandra.exceptions.UnavailableException
-
-
Uses of UnavailableException in org.apache.cassandra.exceptions
Methods in org.apache.cassandra.exceptions that return UnavailableException Modifier and Type Method Description static UnavailableException
UnavailableException. create(ConsistencyLevel consistency, int required, int alive)
static UnavailableException
UnavailableException. create(ConsistencyLevel consistency, int required, int requiredFull, int alive, int aliveFull)
static UnavailableException
UnavailableException. create(ConsistencyLevel consistency, java.lang.String dc, int required, int requiredFull, int alive, int aliveFull)
-
Uses of UnavailableException in org.apache.cassandra.locator
Methods in org.apache.cassandra.locator that throw UnavailableException Modifier and Type Method Description static ReplicaPlan.ForWrite
ReplicaPlans. forBatchlogWrite(boolean isAny)
Requires that the provided endpoints are alive.static ReplicaPlan.ForPaxosWrite
ReplicaPlans. forPaxos(Keyspace keyspace, DecoratedKey key, ConsistencyLevel consistencyForPaxos)
Construct the plan for a paxos round - NOT the write or read consistency level for either the write or comparison, but for the paxos linearisation agreement.static ReplicaPlan.ForWrite
ReplicaPlans. forReadRepair(Token token, ReplicaPlan<?,?> readPlan)
static ReplicaPlan.ForWrite
ReplicaPlans. forWrite(Keyspace keyspace, ConsistencyLevel consistencyLevel, Token token, ReplicaPlans.Selector selector)
static ReplicaPlan.ForWrite
ReplicaPlans. forWrite(Keyspace keyspace, ConsistencyLevel consistencyLevel, EndpointsForToken natural, EndpointsForToken pending, java.util.function.Predicate<Replica> isAlive, ReplicaPlans.Selector selector)
static ReplicaPlan.ForWrite
ReplicaPlans. forWrite(Keyspace keyspace, ConsistencyLevel consistencyLevel, ReplicaLayout.ForTokenWrite liveAndDown, ReplicaLayout.ForTokenWrite live, ReplicaPlans.Selector selector)
static ReplicaPlan.ForWrite
ReplicaPlans. forWrite(Keyspace keyspace, ConsistencyLevel consistencyLevel, ReplicaLayout.ForTokenWrite liveAndDown, ReplicaPlans.Selector selector)
-
Uses of UnavailableException in org.apache.cassandra.service
Methods in org.apache.cassandra.service that throw UnavailableException Modifier and Type Method Description static AbstractWriteResponseHandler<IMutation>
StorageProxy. applyCounterMutationOnCoordinator(CounterMutation cm, java.lang.String localDataCenter, long queryStartNanoTime)
static AbstractWriteResponseHandler<IMutation>
StorageProxy. applyCounterMutationOnLeader(CounterMutation cm, java.lang.String localDataCenter, java.lang.Runnable callback, long queryStartNanoTime)
static RowIterator
StorageProxy. cas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState clientState, long 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, long nowInSeconds, long queryStartNanoTime)
static void
StorageProxy. mutate(java.util.List<? extends IMutation> mutations, ConsistencyLevel consistencyLevel, long queryStartNanoTime)
Use this method to have these Mutations applied across all replicas.static void
StorageProxy. mutateAtomically(java.util.Collection<Mutation> mutations, ConsistencyLevel consistency_level, boolean requireQuorumForRemove, long queryStartNanoTime)
See mutate.static AbstractWriteResponseHandler<IMutation>
StorageProxy. mutateCounter(CounterMutation cm, java.lang.String localDataCenter, long queryStartNanoTime)
Handle counter mutation on the coordinator host.static void
StorageProxy. mutateMV(java.nio.ByteBuffer dataKey, java.util.Collection<Mutation> mutations, boolean writeCommitLog, java.util.concurrent.atomic.AtomicLong baseComplete, long queryStartNanoTime)
Use this method to have these Mutations applied across all replicas.static void
StorageProxy. mutateWithTriggers(java.util.List<? extends IMutation> mutations, ConsistencyLevel consistencyLevel, boolean mutateAtomically, long queryStartNanoTime)
static PartitionIterator
StorageProxy. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyLevel, long queryStartNanoTime)
Performs the actual reading of a row out of the StorageService, fetching a specific set of column names from a given column family.static RowIterator
StorageProxy. readOne(SinglePartitionReadCommand command, ConsistencyLevel consistencyLevel, long queryStartNanoTime)
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 -
Uses of UnavailableException in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos that throw UnavailableException Modifier and Type Method 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 PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus)
static PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus, long deadline)
-
Uses of UnavailableException in org.apache.cassandra.service.reads
Methods in org.apache.cassandra.service.reads that throw UnavailableException Modifier and Type Method Description static AbstractReadExecutor
AbstractReadExecutor. getReadExecutor(SinglePartitionReadCommand command, ConsistencyLevel consistencyLevel, long queryStartNanoTime)
-