Uses of Class
org.apache.cassandra.db.ConsistencyLevel
-
-
Uses of ConsistencyLevel in org.apache.cassandra.auth
Methods in org.apache.cassandra.auth that return ConsistencyLevel Modifier and Type Method Description static ConsistencyLevel
CassandraAuthorizer. authReadConsistencyLevel()
static ConsistencyLevel
CassandraAuthorizer. authWriteConsistencyLevel()
protected static ConsistencyLevel
CassandraRoleManager. consistencyForRoleRead(java.lang.String role)
protected static ConsistencyLevel
CassandraRoleManager. consistencyForRoleWrite(java.lang.String role)
Allows selective overriding of the consistency level for specific roles.ConsistencyLevel
AuthProperties. getReadConsistencyLevel()
ConsistencyLevel
AuthPropertiesMXBean. getReadConsistencyLevel()
ConsistencyLevel
AuthProperties. getWriteConsistencyLevel()
ConsistencyLevel
AuthPropertiesMXBean. getWriteConsistencyLevel()
Methods in org.apache.cassandra.auth with parameters of type ConsistencyLevel Modifier and Type Method Description void
AuthProperties. setReadConsistencyLevel(ConsistencyLevel cl)
void
AuthPropertiesMXBean. setReadConsistencyLevel(ConsistencyLevel cl)
void
AuthProperties. setWriteConsistencyLevel(ConsistencyLevel cl)
void
AuthPropertiesMXBean. setWriteConsistencyLevel(ConsistencyLevel cl)
Constructors in org.apache.cassandra.auth with parameters of type ConsistencyLevel Constructor Description AuthProperties(ConsistencyLevel writeConsistencyLevel, ConsistencyLevel readConsistencyLevel, boolean registerMBean)
-
Uses of ConsistencyLevel in org.apache.cassandra.config
Fields in org.apache.cassandra.config declared as ConsistencyLevel Modifier and Type Field Description ConsistencyLevel
Config. denylist_consistency_level
Since the denylist in many ways serves to protect the health of the cluster from partitions operators have identified as being in a bad state, we usually want more robustness than just CL.ONE on operations to/from these tables to ensure that these safeguards are in place.ConsistencyLevel
Config. ideal_consistency_level
Maintain statistics on whether writes achieve the ideal consistency level before expiring and becoming hintsFields in org.apache.cassandra.config with type parameters of type ConsistencyLevel Modifier and Type Field Description java.util.Set<ConsistencyLevel>
Config. read_consistency_levels_disallowed
java.util.Set<ConsistencyLevel>
Config. read_consistency_levels_warned
java.util.Set<ConsistencyLevel>
Config. write_consistency_levels_disallowed
java.util.Set<ConsistencyLevel>
Config. write_consistency_levels_warned
Methods in org.apache.cassandra.config that return ConsistencyLevel Modifier and Type Method Description static ConsistencyLevel
DatabaseDescriptor. getAuthReadConsistencyLevel()
static ConsistencyLevel
DatabaseDescriptor. getAuthWriteConsistencyLevel()
Deprecated.See CASSANDRA-17195static ConsistencyLevel
DatabaseDescriptor. getDenylistConsistencyLevel()
static ConsistencyLevel
DatabaseDescriptor. getIdealConsistencyLevel()
Methods in org.apache.cassandra.config that return types with arguments of type ConsistencyLevel Modifier and Type Method Description java.util.Set<ConsistencyLevel>
GuardrailsOptions. getReadConsistencyLevelsDisallowed()
java.util.Set<ConsistencyLevel>
GuardrailsOptions. getReadConsistencyLevelsWarned()
java.util.Set<ConsistencyLevel>
GuardrailsOptions. getWriteConsistencyLevelsDisallowed()
java.util.Set<ConsistencyLevel>
GuardrailsOptions. getWriteConsistencyLevelsWarned()
Methods in org.apache.cassandra.config with parameters of type ConsistencyLevel Modifier and Type Method Description static void
DatabaseDescriptor. setAuthReadConsistencyLevel(ConsistencyLevel cl)
static void
DatabaseDescriptor. setAuthWriteConsistencyLevel(ConsistencyLevel cl)
static void
DatabaseDescriptor. setDenylistConsistencyLevel(ConsistencyLevel cl)
static void
DatabaseDescriptor. setIdealConsistencyLevel(ConsistencyLevel cl)
Method parameters in org.apache.cassandra.config with type arguments of type ConsistencyLevel Modifier and Type Method Description void
GuardrailsOptions. setReadConsistencyLevelsDisallowed(java.util.Set<ConsistencyLevel> consistencyLevels)
void
GuardrailsOptions. setReadConsistencyLevelsWarned(java.util.Set<ConsistencyLevel> consistencyLevels)
void
GuardrailsOptions. setWriteConsistencyLevelsDisallowed(java.util.Set<ConsistencyLevel> consistencyLevels)
void
GuardrailsOptions. setWriteConsistencyLevelsWarned(java.util.Set<ConsistencyLevel> consistencyLevels)
-
Uses of ConsistencyLevel in org.apache.cassandra.cql3
Methods in org.apache.cassandra.cql3 that return ConsistencyLevel Modifier and Type Method Description ConsistencyLevel
BatchQueryOptions. getConsistency()
abstract ConsistencyLevel
QueryOptions. getConsistency()
ConsistencyLevel
BatchQueryOptions. getSerialConsistency()
ConsistencyLevel
QueryOptions. getSerialConsistency()
Serial consistency for conditional updates.Methods in org.apache.cassandra.cql3 with parameters of type ConsistencyLevel Modifier and Type Method Description static QueryOptions
QueryOptions. create(ConsistencyLevel consistency, java.util.List<java.nio.ByteBuffer> values, boolean skipMetadata, int pageSize, PagingState pagingState, ConsistencyLevel serialConsistency, ProtocolVersion version, java.lang.String keyspace)
static QueryOptions
QueryOptions. create(ConsistencyLevel consistency, java.util.List<java.nio.ByteBuffer> values, boolean skipMetadata, int pageSize, PagingState pagingState, ConsistencyLevel serialConsistency, ProtocolVersion version, java.lang.String keyspace, long timestamp, long nowInSeconds)
static UntypedResultSet
UntypedResultSet. create(SelectStatement select, ConsistencyLevel cl, ClientState clientState, QueryPager pager, int pageSize)
This method is intended for testing purposes, since it executes query on cluster and not on the local node only.static UntypedResultSet
QueryProcessor. execute(java.lang.String query, ConsistencyLevel cl, java.lang.Object... values)
static UntypedResultSet
QueryProcessor. execute(java.lang.String query, ConsistencyLevel cl, QueryState state, java.lang.Object... values)
static QueryOptions
QueryOptions. forInternalCalls(ConsistencyLevel consistency, java.util.List<java.nio.ByteBuffer> values)
static QueryOptions
QueryOptions. forInternalCallsWithNowInSec(long nowInSec, ConsistencyLevel consistency, java.util.List<java.nio.ByteBuffer> values)
static UntypedResultSet
QueryProcessor. process(java.lang.String query, ConsistencyLevel cl)
static UntypedResultSet
QueryProcessor. process(java.lang.String query, ConsistencyLevel cl, java.util.List<java.nio.ByteBuffer> values)
static ResultMessage
QueryProcessor. process(java.lang.String queryString, ConsistencyLevel cl, QueryState queryState, Dispatcher.RequestTime requestTime)
static QueryOptions
QueryOptions. withConsistencyLevel(QueryOptions options, ConsistencyLevel consistencyLevel)
-
Uses of ConsistencyLevel in org.apache.cassandra.cql3.statements
Methods in org.apache.cassandra.cql3.statements with parameters of type ConsistencyLevel Modifier and Type Method Description PartitionUpdate.Builder
UpdatesCollector. getPartitionUpdateBuilder(TableMetadata metadata, DecoratedKey dk, ConsistencyLevel consistency)
-
Uses of ConsistencyLevel in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return ConsistencyLevel Modifier and Type Method Description ConsistencyLevel
CounterMutation. consistency()
static ConsistencyLevel
ConsistencyLevel. fromCode(int code)
static ConsistencyLevel
ConsistencyLevel. fromString(java.lang.String str)
static ConsistencyLevel
ConsistencyLevel. valueOf(java.lang.String name)
Returns the enum constant of this type with the specified name.static ConsistencyLevel[]
ConsistencyLevel. values()
Returns an array containing the constants of this enum type, in the order they are declared.Methods in org.apache.cassandra.db with parameters of type ConsistencyLevel Modifier and Type Method Description PartitionIterator
PartitionRangeReadCommand. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
PartitionIterator
PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
PartitionIterator
ReadQuery. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
Executes the query at the provided consistency level.PartitionIterator
SinglePartitionReadCommand. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
PartitionIterator
SinglePartitionReadCommand.Group. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
PartitionIterator
SinglePartitionReadCommand.VirtualTableGroup. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
PartitionIterator
SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand. execute(ConsistencyLevel consistency, ClientState state, Dispatcher.RequestTime requestTime)
boolean
ConsistencyLevel. satisfies(ConsistencyLevel other, AbstractReplicationStrategy replicationStrategy)
Determine if this consistency level meets or exceeds the consistency requirements of the given cl for the given keyspace WARNING: this is not locality aware; you cannot safely use this with mixed locality consistency levels (e.g.Constructors in org.apache.cassandra.db with parameters of type ConsistencyLevel Constructor Description CounterMutation(Mutation mutation, ConsistencyLevel consistency)
-
Uses of ConsistencyLevel in org.apache.cassandra.db.guardrails
Fields in org.apache.cassandra.db.guardrails with type parameters of type ConsistencyLevel Modifier and Type Field Description static Values<ConsistencyLevel>
Guardrails. readConsistencyLevels
Guardrail on read consistency levels.static Values<ConsistencyLevel>
Guardrails. writeConsistencyLevels
Guardrail on write consistency levels.Methods in org.apache.cassandra.db.guardrails that return types with arguments of type ConsistencyLevel Modifier and Type Method Description java.util.Set<ConsistencyLevel>
GuardrailsConfig. getReadConsistencyLevelsDisallowed()
java.util.Set<ConsistencyLevel>
GuardrailsConfig. getReadConsistencyLevelsWarned()
java.util.Set<ConsistencyLevel>
GuardrailsConfig. getWriteConsistencyLevelsDisallowed()
java.util.Set<ConsistencyLevel>
GuardrailsConfig. getWriteConsistencyLevelsWarned()
-
Uses of ConsistencyLevel in org.apache.cassandra.exceptions
Fields in org.apache.cassandra.exceptions declared as ConsistencyLevel Modifier and Type Field Description ConsistencyLevel
CasWriteUnknownResultException. consistency
ConsistencyLevel
RequestFailureException. consistency
ConsistencyLevel
RequestTimeoutException. consistency
ConsistencyLevel
UnavailableException. consistency
Methods in org.apache.cassandra.exceptions with parameters of type ConsistencyLevel 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)
Constructors in org.apache.cassandra.exceptions with parameters of type ConsistencyLevel Constructor Description CasWriteTimeoutException(WriteType writeType, ConsistencyLevel consistency, int received, int blockFor, int contentions)
CasWriteUnknownResultException(ConsistencyLevel consistency, int received, int blockFor)
QueryReferencesTooManyIndexesAbortException(java.lang.String msg, int nodes, long maxValue, boolean dataPresent, ConsistencyLevel consistency, int received, int blockFor, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
ReadAbortException(java.lang.String msg, ConsistencyLevel consistency, int received, int blockFor, boolean dataPresent, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
ReadFailureException(java.lang.String msg, ConsistencyLevel consistency, int received, int blockFor, boolean dataPresent, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
ReadFailureException(ConsistencyLevel consistency, int received, int blockFor, boolean dataPresent, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
ReadSizeAbortException(java.lang.String msg, ConsistencyLevel consistency, int received, int blockFor, boolean dataPresent, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
ReadTimeoutException(ConsistencyLevel consistency, int received, int blockFor, boolean dataPresent)
RequestFailureException(ExceptionCode code, java.lang.String msg, ConsistencyLevel consistency, int received, int blockFor, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
RequestFailureException(ExceptionCode code, ConsistencyLevel consistency, int received, int blockFor, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
RequestTimeoutException(ExceptionCode code, ConsistencyLevel consistency, int received, int blockFor)
RequestTimeoutException(ExceptionCode code, ConsistencyLevel consistency, int received, int blockFor, java.lang.String msg)
TombstoneAbortException(java.lang.String message, int nodes, long tombstones, boolean dataPresent, ConsistencyLevel consistency, int received, int blockFor, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
UnavailableException(java.lang.String msg, ConsistencyLevel consistency, int required, int alive)
WriteFailureException(ConsistencyLevel consistency, int received, int blockFor, WriteType writeType, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
WriteTimeoutException(WriteType writeType, ConsistencyLevel consistency, int received, int blockFor)
WriteTimeoutException(WriteType writeType, ConsistencyLevel consistency, int received, int blockFor, java.lang.String msg)
-
Uses of ConsistencyLevel in org.apache.cassandra.index
Methods in org.apache.cassandra.index with parameters of type ConsistencyLevel Modifier and Type Method Description <E extends Endpoints<E>>
EIndexStatusManager. filterForQuery(E liveEndpoints, Keyspace keyspace, Index.QueryPlan indexQueryPlan, ConsistencyLevel level)
Remove endpoints whose indexes are not queryable for the specifiedIndex.QueryPlan
. -
Uses of ConsistencyLevel in org.apache.cassandra.locator
Fields in org.apache.cassandra.locator declared as ConsistencyLevel Modifier and Type Field Description protected ConsistencyLevel
ReplicaPlan.AbstractReplicaPlan. consistencyLevel
Methods in org.apache.cassandra.locator that return ConsistencyLevel Modifier and Type Method Description ConsistencyLevel
ReplicaPlan.AbstractReplicaPlan. consistencyLevel()
ConsistencyLevel
ReplicaPlan. consistencyLevel()
Methods in org.apache.cassandra.locator with parameters of type ConsistencyLevel Modifier and Type Method Description static ReplicaPlan.ForRangeRead
ReplicaPlans. forFullRangeRead(Keyspace keyspace, ConsistencyLevel consistencyLevel, AbstractBounds<PartitionPosition> range, java.util.Set<InetAddressAndPort> endpointsToContact, int vnodeCount)
Construct a plan for reading the provided range at the provided consistency level on given endpoints.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.ForRangeRead
ReplicaPlans. forRangeRead(Keyspace keyspace, Index.QueryPlan indexQueryPlan, ConsistencyLevel consistencyLevel, AbstractBounds<PartitionPosition> range, int vnodeCount)
Construct a plan for reading the provided range at the provided consistency level.static ReplicaPlan.ForTokenRead
ReplicaPlans. forRead(Keyspace keyspace, Token token, Index.QueryPlan indexQueryPlan, ConsistencyLevel consistencyLevel, SpeculativeRetryPolicy retry)
Construct a plan for reading the provided token at the provided consistency level.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)
<T> AbstractWriteResponseHandler<T>
AbstractReplicationStrategy. getWriteResponseHandler(ReplicaPlan.ForWrite replicaPlan, java.lang.Runnable callback, WriteType writeType, java.util.function.Supplier<Mutation> hintOnFailure, Dispatcher.RequestTime requestTime, ConsistencyLevel idealConsistencyLevel)
static boolean
ReplicaPlans. isSufficientLiveReplicasForRead(AbstractReplicationStrategy replicationStrategy, ConsistencyLevel consistencyLevel, Endpoints<?> liveReplicas)
static ReplicaPlan.ForRangeRead
ReplicaPlans. maybeMerge(Keyspace keyspace, ConsistencyLevel consistencyLevel, ReplicaPlan.ForRangeRead left, ReplicaPlan.ForRangeRead right)
Take two range read plans for adjacent ranges, and check if it is OK (and worthwhile) to combine them into a single plan<E extends Endpoints<E>,L extends ReplicaLayout.ForWrite<E>>
EReplicaPlans.Selector. select(ConsistencyLevel consistencyLevel, L liveAndDown, L live)
Select theEndpoints
from {@param liveAndDown} and {@param live} to contact according to the consistency level.Constructors in org.apache.cassandra.locator with parameters of type ConsistencyLevel Constructor Description ForFullRangeRead(Keyspace keyspace, AbstractReplicationStrategy replicationStrategy, ConsistencyLevel consistencyLevel, AbstractBounds<PartitionPosition> range, EndpointsForRange candidates, EndpointsForRange contact, int vnodeCount)
ForRangeRead(Keyspace keyspace, AbstractReplicationStrategy replicationStrategy, ConsistencyLevel consistencyLevel, AbstractBounds<PartitionPosition> range, EndpointsForRange candidates, EndpointsForRange contact, int vnodeCount)
ForTokenRead(Keyspace keyspace, AbstractReplicationStrategy replicationStrategy, ConsistencyLevel consistencyLevel, EndpointsForToken candidates, EndpointsForToken contacts)
ForWrite(Keyspace keyspace, AbstractReplicationStrategy replicationStrategy, ConsistencyLevel consistencyLevel, EndpointsForToken pending, EndpointsForToken liveAndDown, EndpointsForToken live, EndpointsForToken contact)
-
Uses of ConsistencyLevel in org.apache.cassandra.metrics
Fields in org.apache.cassandra.metrics with type parameters of type ConsistencyLevel Modifier and Type Field Description static java.util.Map<ConsistencyLevel,ClientRequestMetrics>
ClientRequestsMetricsHolder. readMetricsMap
static java.util.Map<ConsistencyLevel,ClientWriteRequestMetrics>
ClientRequestsMetricsHolder. writeMetricsMap
Methods in org.apache.cassandra.metrics with parameters of type ConsistencyLevel Modifier and Type Method Description static ClientRequestMetrics
ClientRequestsMetricsHolder. readMetricsForLevel(ConsistencyLevel level)
static ClientWriteRequestMetrics
ClientRequestsMetricsHolder. writeMetricsForLevel(ConsistencyLevel level)
-
Uses of ConsistencyLevel in org.apache.cassandra.service
Methods in org.apache.cassandra.service that return ConsistencyLevel Modifier and Type Method Description ConsistencyLevel
AbstractWriteResponseHandler. consistencyLevel()
Methods in org.apache.cassandra.service with parameters of type ConsistencyLevel Modifier and Type Method Description static RowIterator
StorageProxy. cas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState clientState, long nowInSeconds, Dispatcher.RequestTime requestTime)
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions.static PartitionIterator
StorageProxy. getRangeSlice(PartitionRangeReadCommand command, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
static RowIterator
StorageProxy. legacyCas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState clientState, long nowInSeconds, Dispatcher.RequestTime requestTime)
static void
StorageProxy. mutate(java.util.List<? extends IMutation> mutations, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
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, Dispatcher.RequestTime requestTime)
See mutate.static void
StorageProxy. mutateWithTriggers(java.util.List<? extends IMutation> mutations, ConsistencyLevel consistencyLevel, boolean mutateAtomically, Dispatcher.RequestTime requestTime)
static AbstractWriteResponseHandler<IMutation>
StorageProxy. performWrite(IMutation mutation, ConsistencyLevel consistencyLevel, java.lang.String localDataCenter, StorageProxy.WritePerformer performer, java.lang.Runnable callback, WriteType writeType, Dispatcher.RequestTime requestTime)
Perform the write of a mutation given a WritePerformer.static PartitionIterator
StorageProxy. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
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, Dispatcher.RequestTime requestTime)
static void
StorageProxy. recordReadRegularAbort(ConsistencyLevel consistencyLevel, java.lang.Throwable cause)
-
Uses of ConsistencyLevel in org.apache.cassandra.service.pager
Methods in org.apache.cassandra.service.pager with parameters of type ConsistencyLevel Modifier and Type Method Description PartitionIterator
AggregationQueryPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, Dispatcher.RequestTime requestTime)
PartitionIterator
MultiPartitionPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, Dispatcher.RequestTime requestTime)
PartitionIterator
QueryPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, Dispatcher.RequestTime requestTime)
Fetches the next page.Constructors in org.apache.cassandra.service.pager with parameters of type ConsistencyLevel Constructor Description AggregationPartitionIterator(int pageSize, ConsistencyLevel consistency, ClientState clientState, Dispatcher.RequestTime requestTime)
GroupByPartitionIterator(int pageSize, ConsistencyLevel consistency, ClientState clientState, Dispatcher.RequestTime requestTime)
-
Uses of ConsistencyLevel in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos that return ConsistencyLevel Modifier and Type Method Description static ConsistencyLevel
Paxos. consistency(Ballot ballot)
Methods in org.apache.cassandra.service.paxos with parameters of type ConsistencyLevel Modifier and Type Method Description static Ballot
Paxos. ballotForConsistency(long whenInMicros, ConsistencyLevel consistency)
Create a ballot uuid with the consistency level encoded in the timestamp.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 PaxosRepair
PaxosRepair. create(ConsistencyLevel consistency, DecoratedKey partitionKey, Ballot incompleteBallot, TableMetadata table)
static PaxosOperationLock
PaxosState. lock(DecoratedKey partitionKey, TableMetadata metadata, long deadline, ConsistencyLevel consistencyForConsensus, boolean isWrite)
static Ballot
Paxos. newBallot(Ballot minimumBallot, ConsistencyLevel consistency)
static PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus, long deadline)
static PartitionIterator
Paxos. read(SinglePartitionReadCommand.Group group, ConsistencyLevel consistencyForConsensus, Dispatcher.RequestTime requestTime)
Constructors in org.apache.cassandra.service.paxos with parameters of type ConsistencyLevel Constructor Description PaxosCommit(Commit.Agreed commit, boolean allowHints, ConsistencyLevel consistencyForConsensus, ConsistencyLevel consistencyForCommit, org.apache.cassandra.service.paxos.Paxos.Participants participants, OnDone onDone)
-
Uses of ConsistencyLevel in org.apache.cassandra.service.paxos.uncommitted
Methods in org.apache.cassandra.service.paxos.uncommitted that return ConsistencyLevel Modifier and Type Method Description ConsistencyLevel
PaxosKeyState. getConsistencyLevel()
ConsistencyLevel
UncommittedPaxosKey. getConsistencyLevel()
-
Uses of ConsistencyLevel in org.apache.cassandra.service.paxos.v1
Constructors in org.apache.cassandra.service.paxos.v1 with parameters of type ConsistencyLevel Constructor Description AbstractPaxosCallback(int targets, ConsistencyLevel consistency, Dispatcher.RequestTime requestTime)
PrepareCallback(DecoratedKey key, TableMetadata metadata, int targets, ConsistencyLevel consistency, Dispatcher.RequestTime requestTime)
ProposeCallback(int totalTargets, int requiredTargets, boolean failFast, ConsistencyLevel consistency, Dispatcher.RequestTime requestTime)
-
Uses of ConsistencyLevel in org.apache.cassandra.service.reads
Methods in org.apache.cassandra.service.reads with parameters of type ConsistencyLevel Modifier and Type Method Description static AbstractReadExecutor
AbstractReadExecutor. getReadExecutor(SinglePartitionReadCommand command, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
-
Uses of ConsistencyLevel in org.apache.cassandra.service.reads.range
Methods in org.apache.cassandra.service.reads.range with parameters of type ConsistencyLevel Modifier and Type Method Description static PartitionIterator
RangeCommands. partitions(PartitionRangeReadCommand command, ConsistencyLevel consistencyLevel, Dispatcher.RequestTime requestTime)
static boolean
RangeCommands. sufficientLiveNodesForSelectStar(TableMetadata metadata, ConsistencyLevel consistency)
Added specifically to check for sufficient nodes live to serve partition denylist queries -
Uses of ConsistencyLevel in org.apache.cassandra.service.reads.repair
Methods in org.apache.cassandra.service.reads.repair with parameters of type ConsistencyLevel Modifier and Type Method Description static Mutation
BlockingReadRepairs. createRepairMutation(PartitionUpdate update, ConsistencyLevel consistency, InetAddressAndPort destination, boolean suppressException)
Create a read repair mutation from the given update, if the mutation is not larger than the maximum mutation size, otherwise return null. -
Uses of ConsistencyLevel in org.apache.cassandra.service.reads.thresholds
Methods in org.apache.cassandra.service.reads.thresholds with parameters of type ConsistencyLevel Modifier and Type Method Description void
WarningsSnapshot. maybeAbort(ReadCommand command, ConsistencyLevel cl, int received, int blockFor, boolean isDataPresent, java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint)
-
Uses of ConsistencyLevel in org.apache.cassandra.transport
Methods in org.apache.cassandra.transport that return ConsistencyLevel Modifier and Type Method Description static ConsistencyLevel
CBUtil. readConsistencyLevel(io.netty.buffer.ByteBuf cb)
Methods in org.apache.cassandra.transport with parameters of type ConsistencyLevel Modifier and Type Method Description ResultMessage
SimpleClient. execute(java.lang.String query, java.util.List<java.nio.ByteBuffer> values, ConsistencyLevel consistencyLevel)
ResultMessage
SimpleClient. execute(java.lang.String query, ConsistencyLevel consistency)
ResultMessage
SimpleClient. executePrepared(ResultMessage.Prepared prepared, java.util.List<java.nio.ByteBuffer> values, ConsistencyLevel consistency)
static int
CBUtil. sizeOfConsistencyLevel(ConsistencyLevel consistency)
static void
CBUtil. writeConsistencyLevel(ConsistencyLevel consistency, io.netty.buffer.ByteBuf cb)
-