Uses of Class
org.apache.cassandra.service.ClientState
-
-
Uses of ClientState in org.apache.cassandra.cql3
Fields in org.apache.cassandra.cql3 declared as ClientState Modifier and Type Field Description ClientState
UpdateParameters. clientState
Methods in org.apache.cassandra.cql3 with parameters of type ClientState Modifier and Type Method Description void
CQLStatement. authorize(ClientState state)
Perform any access verification necessary for the statement.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 CQLStatement
QueryProcessor. getStatement(java.lang.String queryStr, ClientState clientState)
static QueryHandler.Prepared
QueryProcessor. parseAndPrepare(java.lang.String query, ClientState clientState, boolean isInternal)
static CQLStatement
QueryProcessor. parseStatement(java.lang.String queryStr, ClientState clientState)
abstract CQLStatement
CQLStatement.Raw. prepare(ClientState state)
ResultMessage.Prepared
CustomPayloadMirroringQueryHandler. prepare(java.lang.String query, ClientState clientState, java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload)
ResultMessage.Prepared
QueryHandler. prepare(java.lang.String query, ClientState clientState, java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload)
ResultMessage.Prepared
QueryProcessor. prepare(java.lang.String queryString, ClientState clientState)
This method got slightly out of hand, but this is with best intentions: to allow users to be upgraded from any prior version, and help implementers avoid previous mistakes by clearly separating fully qualified and non-fully qualified statement behaviour.ResultMessage.Prepared
QueryProcessor. prepare(java.lang.String query, ClientState clientState, java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload)
abstract void
CQL3Type.Raw. validate(ClientState state, java.lang.String name)
void
CQLStatement. validate(ClientState state)
Perform additional validation required by the statment.Constructors in org.apache.cassandra.cql3 with parameters of type ClientState Constructor Description UpdateParameters(TableMetadata metadata, RegularAndStaticColumns updatedColumns, ClientState clientState, QueryOptions options, long timestamp, long nowInSec, int ttl, java.util.Map<DecoratedKey,Partition> prefetchedRows)
-
Uses of ClientState in org.apache.cassandra.cql3.restrictions
Methods in org.apache.cassandra.cql3.restrictions with parameters of type ClientState Modifier and Type Method Description java.util.NavigableSet<Clustering<?>>
StatementRestrictions. getClusteringColumns(QueryOptions options, ClientState state)
Returns the requested clustering columns.java.util.List<java.nio.ByteBuffer>
StatementRestrictions. getPartitionKeys(QueryOptions options, ClientState state)
Returns the partition keys for which the data is requested.java.util.List<java.nio.ByteBuffer>
TokenRestriction.EQRestriction. values(QueryOptions options, ClientState state)
java.util.List<java.nio.ByteBuffer>
TokenRestriction.SliceRestriction. values(QueryOptions options, ClientState state)
Constructors in org.apache.cassandra.cql3.restrictions with parameters of type ClientState Constructor Description StatementRestrictions(ClientState state, StatementType type, TableMetadata table, WhereClause whereClause, VariableSpecifications boundNames, java.util.List<Ordering> orderings, boolean selectsOnlyStaticColumns, boolean allowFiltering, boolean forView)
StatementRestrictions(ClientState state, StatementType type, TableMetadata table, WhereClause whereClause, VariableSpecifications boundNames, java.util.List<Ordering> orderings, boolean selectsOnlyStaticColumns, boolean allowUseOfSecondaryIndices, boolean allowFiltering, boolean forView)
-
Uses of ClientState in org.apache.cassandra.cql3.statements
Methods in org.apache.cassandra.cql3.statements with parameters of type ClientState Modifier and Type Method Description void
AddIdentityStatement. authorize(ClientState state)
void
AlterRoleStatement. authorize(ClientState state)
void
BatchStatement. authorize(ClientState state)
void
CreateRoleStatement. authorize(ClientState state)
void
DescribeStatement. authorize(ClientState state)
void
DropIdentityStatement. authorize(ClientState state)
void
DropRoleStatement. authorize(ClientState state)
void
ListPermissionsStatement. authorize(ClientState state)
void
ListRolesStatement. authorize(ClientState state)
void
ModificationStatement. authorize(ClientState state)
void
PermissionsManagementStatement. authorize(ClientState state)
void
RoleManagementStatement. authorize(ClientState state)
void
SelectStatement. authorize(ClientState state)
void
TruncateStatement. authorize(ClientState state)
void
UseStatement. authorize(ClientState state)
java.util.List<java.nio.ByteBuffer>
ModificationStatement. buildPartitionKeyNames(QueryOptions options, ClientState state)
void
AuthenticationStatement. checkPermission(ClientState state, Permission required, RoleResource resource)
java.util.NavigableSet<Clustering<?>>
ModificationStatement. createClustering(QueryOptions options, ClientState state)
protected abstract java.util.stream.Stream<? extends T>
DescribeStatement. describe(ClientState state, Keyspaces keyspaces)
Returns the schema elements that must be part of the output.protected java.util.stream.Stream<? extends SchemaElement>
DescribeStatement.Element. describe(ClientState state, Keyspaces keyspaces)
protected java.util.stream.Stream<? extends SchemaElement>
DescribeStatement.Listing. describe(ClientState state, Keyspaces keyspaces)
ResultMessage
AddIdentityStatement. execute(ClientState state)
ResultMessage
AlterRoleStatement. execute(ClientState state)
abstract ResultMessage
AuthenticationStatement. execute(ClientState state)
abstract ResultMessage
AuthorizationStatement. execute(ClientState state)
ResultMessage
CreateRoleStatement. execute(ClientState state)
ResultMessage
DropIdentityStatement. execute(ClientState state)
ResultMessage
DropRoleStatement. execute(ClientState state)
ResultMessage
GrantPermissionsStatement. execute(ClientState state)
ResultMessage
GrantRoleStatement. execute(ClientState state)
ResultMessage
ListPermissionsStatement. execute(ClientState state)
ResultMessage
ListRolesStatement. execute(ClientState state)
ResultMessage
RevokePermissionsStatement. execute(ClientState state)
ResultMessage
RevokeRoleStatement. execute(ClientState state)
java.util.Map<DecoratedKey,java.util.List<Row>>
SelectStatement. executeRawInternal(QueryOptions options, ClientState state, long nowInSec)
java.util.List<? extends IMutation>
BatchStatement. getMutations(ClientState state, BatchQueryOptions options, boolean local, long batchTimestamp, long nowInSeconds, long queryStartNanoTime)
ReadQuery
SelectStatement. getQuery(QueryOptions options, ClientState state, ColumnFilter columnFilter, long nowInSec, int userLimit, int perPartitionLimit, int pageSize, AggregationSpecification aggregationSpec)
ReadQuery
SelectStatement. getQuery(QueryOptions options, ClientState state, ColumnFilter columnFilter, long nowInSec, DataLimits limit)
PartitionUpdate
CQL3CasRequest. makeUpdates(FilteredPartition current, ClientState clientState, Ballot ballot)
static IResource
AuthorizationStatement. maybeCorrectResource(IResource resource, ClientState state)
protected java.util.List<ColumnSpecification>
DescribeStatement.Element. metadata(ClientState state)
protected java.util.List<ColumnSpecification>
DescribeStatement.Listing. metadata(ClientState state)
protected abstract java.util.List<ColumnSpecification>
DescribeStatement. metadata(ClientState state)
Returns the columns of theResultMetadata
protected StatementRestrictions
ModificationStatement.Parsed. newRestrictions(ClientState state, TableMetadata metadata, VariableSpecifications boundNames, Operations operations, WhereClause where, Conditions conditions, java.util.List<Ordering> orderings)
Creates the restrictions.AuthenticationStatement
AuthenticationStatement. prepare(ClientState state)
AuthorizationStatement
AuthorizationStatement. prepare(ClientState state)
BatchStatement
BatchStatement.Parsed. prepare(ClientState state)
CQLStatement
DescribeStatement. prepare(ClientState clientState)
ModificationStatement
ModificationStatement.Parsed. prepare(ClientState state)
ModificationStatement
ModificationStatement.Parsed. prepare(ClientState state, VariableSpecifications bindVariables)
SelectStatement
SelectStatement.RawStatement. prepare(ClientState state)
SelectStatement
SelectStatement.RawStatement. prepare(ClientState state, boolean forView)
TruncateStatement
TruncateStatement. prepare(ClientState state)
UseStatement
UseStatement. prepare(ClientState state)
protected ModificationStatement
DeleteStatement.Parsed. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected abstract ModificationStatement
ModificationStatement.Parsed. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedInsert. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedInsertJson. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedUpdate. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
void
BatchStatement.Parsed. setKeyspace(ClientState state)
void
QualifiedStatement. setKeyspace(ClientState state)
void
AddIdentityStatement. validate(ClientState state)
void
AlterRoleStatement. validate(ClientState state)
void
BatchStatement. validate(ClientState state)
void
CreateRoleStatement. validate(ClientState state)
void
DescribeStatement. validate(ClientState state)
void
DropIdentityStatement. validate(ClientState state)
void
DropRoleStatement. validate(ClientState state)
void
ListPermissionsStatement. validate(ClientState state)
void
ListRolesStatement. validate(ClientState state)
void
ModificationStatement. validate(ClientState state)
void
PermissionsManagementStatement. validate(ClientState state)
void
RoleManagementStatement. validate(ClientState state)
void
SelectStatement. validate(ClientState state)
void
TruncateStatement. validate(ClientState state)
void
UseStatement. validate(ClientState state)
void
ModificationStatement. validateDiskUsage(QueryOptions options, ClientState state)
-
Uses of ClientState in org.apache.cassandra.cql3.statements.schema
Fields in org.apache.cassandra.cql3.statements.schema declared as ClientState Modifier and Type Field Description protected ClientState
AlterSchemaStatement. state
protected ClientState
AlterTableStatement. state
Methods in org.apache.cassandra.cql3.statements.schema with parameters of type ClientState Modifier and Type Method Description void
AlterKeyspaceStatement. authorize(ClientState client)
void
AlterTableStatement. authorize(ClientState client)
void
AlterTypeStatement. authorize(ClientState client)
void
AlterViewStatement. authorize(ClientState client)
void
CreateAggregateStatement. authorize(ClientState client)
void
CreateFunctionStatement. authorize(ClientState client)
void
CreateIndexStatement. authorize(ClientState client)
void
CreateKeyspaceStatement. authorize(ClientState client)
void
CreateTableStatement. authorize(ClientState client)
void
CreateTriggerStatement. authorize(ClientState client)
void
CreateTypeStatement. authorize(ClientState client)
void
CreateViewStatement. authorize(ClientState client)
void
DropAggregateStatement. authorize(ClientState client)
void
DropFunctionStatement. authorize(ClientState client)
void
DropIndexStatement. authorize(ClientState client)
void
DropKeyspaceStatement. authorize(ClientState client)
void
DropTableStatement. authorize(ClientState client)
void
DropTriggerStatement. authorize(ClientState client)
void
DropTypeStatement. authorize(ClientState client)
void
DropViewStatement. authorize(ClientState client)
AlterKeyspaceStatement
AlterKeyspaceStatement.Raw. prepare(ClientState state)
AlterTableStatement
AlterTableStatement.Raw. prepare(ClientState state)
AlterTypeStatement
AlterTypeStatement.Raw. prepare(ClientState state)
AlterViewStatement
AlterViewStatement.Raw. prepare(ClientState state)
CreateAggregateStatement
CreateAggregateStatement.Raw. prepare(ClientState state)
CreateFunctionStatement
CreateFunctionStatement.Raw. prepare(ClientState state)
CreateIndexStatement
CreateIndexStatement.Raw. prepare(ClientState state)
CreateKeyspaceStatement
CreateKeyspaceStatement.Raw. prepare(ClientState state)
CreateTableStatement
CreateTableStatement.Raw. prepare(ClientState state)
CreateTriggerStatement
CreateTriggerStatement.Raw. prepare(ClientState state)
CreateTypeStatement
CreateTypeStatement.Raw. prepare(ClientState state)
CreateViewStatement
CreateViewStatement.Raw. prepare(ClientState state)
DropAggregateStatement
DropAggregateStatement.Raw. prepare(ClientState state)
DropFunctionStatement
DropFunctionStatement.Raw. prepare(ClientState state)
DropIndexStatement
DropIndexStatement.Raw. prepare(ClientState state)
DropKeyspaceStatement
DropKeyspaceStatement.Raw. prepare(ClientState state)
DropTableStatement
DropTableStatement.Raw. prepare(ClientState state)
DropTriggerStatement
DropTriggerStatement.Raw. prepare(ClientState state)
DropTypeStatement
DropTypeStatement.Raw. prepare(ClientState state)
DropViewStatement
DropViewStatement.Raw. prepare(ClientState state)
void
AlterSchemaStatement. validate(ClientState state)
void
AlterTableStatement.MaskColumn. validate(ClientState state)
void
AlterTableStatement. validate(ClientState state)
void
AlterViewStatement. validate(ClientState state)
void
CreateIndexStatement. validate(ClientState state)
void
CreateKeyspaceStatement. validate(ClientState state)
void
CreateTableStatement. validate(ClientState state)
void
CreateTypeStatement. validate(ClientState state)
void
CreateViewStatement. validate(ClientState state)
-
Uses of ClientState in org.apache.cassandra.db
Methods in org.apache.cassandra.db with parameters of type ClientState Modifier and Type Method Description PartitionIterator
PartitionRangeReadCommand. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
PartitionIterator
PartitionRangeReadCommand.VirtualTablePartitionRangeReadCommand. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
PartitionIterator
ReadQuery. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
Executes the query at the provided consistency level.PartitionIterator
SinglePartitionReadCommand. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
PartitionIterator
SinglePartitionReadCommand.Group. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
PartitionIterator
SinglePartitionReadCommand.VirtualTableGroup. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
PartitionIterator
SinglePartitionReadCommand.VirtualTableSinglePartitionReadCommand. execute(ConsistencyLevel consistency, ClientState state, long queryStartNanoTime)
-
Uses of ClientState in org.apache.cassandra.db.guardrails
Fields in org.apache.cassandra.db.guardrails with type parameters of type ClientState Modifier and Type Field Description protected java.util.function.ToLongFunction<ClientState>
Threshold. failThreshold
protected java.util.function.ToLongFunction<ClientState>
Threshold. warnThreshold
Methods in org.apache.cassandra.db.guardrails with parameters of type ClientState Modifier and Type Method Description boolean
Guardrail. enabled(ClientState state)
Checks whether this guardrail is enabled or not.boolean
Threshold. enabled(ClientState state)
void
EnableFlag. ensureEnabled(java.lang.String featureName, ClientState state)
Aborts the operation if this guardrail is not enabled.void
EnableFlag. ensureEnabled(ClientState state)
Aborts the operation if this guardrail is not enabled.protected void
Guardrail. fail(java.lang.String message, java.lang.String redactedMessage, ClientState state)
protected void
Guardrail. fail(java.lang.String message, ClientState state)
boolean
Threshold. failsOn(long value, ClientState state)
protected long
MaxThreshold. failValue(ClientState state)
protected long
MinThreshold. failValue(ClientState state)
protected abstract long
Threshold. failValue(ClientState state)
GuardrailsConfig
GuardrailsConfigProvider.Default. getOrCreate(ClientState state)
GuardrailsConfig
GuardrailsConfigProvider. getOrCreate(ClientState state)
Returns theGuardrailsConfig
to be used for the specifiedClientState
.void
Predicates. guard(T value, ClientState state)
Apply the guardrail to the provided value, triggering a warning or failure if appropriate.void
Threshold. guard(long value, java.lang.String what, boolean containsUserData, ClientState state)
Apply the guardrail to the provided value, warning or failing if appropriate.void
Values. guard(java.util.Set<T> values, java.util.function.Consumer<T> ignoreAction, ClientState state)
Triggers a warning for each of the provided values that is discouraged by this guardrail.void
Values. guard(java.util.Set<T> values, ClientState state)
Triggers a warning for each of the provided values that is discouraged by this guardrail.boolean
EnableFlag. isEnabled(ClientState state)
Returns whether the guarded feature is enabled or not.boolean
Threshold. triggersOn(long value, ClientState state)
Checks whether the provided value would trigger a warning or failure if passed toThreshold.guard(long, java.lang.String, boolean, org.apache.cassandra.service.ClientState)
.boolean
Threshold. warnsOn(long value, ClientState state)
protected long
MaxThreshold. warnValue(ClientState state)
protected long
MinThreshold. warnValue(ClientState state)
protected abstract long
Threshold. warnValue(ClientState state)
Constructor parameters in org.apache.cassandra.db.guardrails with type arguments of type ClientState Constructor Description EnableFlag(java.lang.String name, java.lang.String reason, java.util.function.Predicate<ClientState> enabled, java.lang.String featureName)
Creates a newEnableFlag
guardrail.EnableFlag(java.lang.String name, java.lang.String reason, java.util.function.Predicate<ClientState> warned, java.util.function.Predicate<ClientState> enabled, java.lang.String featureName)
Creates a newEnableFlag
guardrail.MaxThreshold(java.lang.String name, java.lang.String reason, java.util.function.ToLongFunction<ClientState> warnThreshold, java.util.function.ToLongFunction<ClientState> failThreshold, org.apache.cassandra.db.guardrails.Threshold.ErrorMessageProvider messageProvider)
Creates a new threshold guardrail.MinThreshold(java.lang.String name, java.lang.String reason, java.util.function.ToLongFunction<ClientState> warnThreshold, java.util.function.ToLongFunction<ClientState> failThreshold, org.apache.cassandra.db.guardrails.Threshold.ErrorMessageProvider messageProvider)
Creates a new minimum threshold guardrail.PercentageThreshold(java.lang.String name, java.lang.String reason, java.util.function.ToLongFunction<ClientState> warnThreshold, java.util.function.ToLongFunction<ClientState> failThreshold, org.apache.cassandra.db.guardrails.Threshold.ErrorMessageProvider messageProvider)
Creates a new threshold guardrail.Threshold(java.lang.String name, java.lang.String reason, java.util.function.ToLongFunction<ClientState> warnThreshold, java.util.function.ToLongFunction<ClientState> failThreshold, org.apache.cassandra.db.guardrails.Threshold.ErrorMessageProvider messageProvider)
Creates a new threshold guardrail.Values(java.lang.String name, java.lang.String reason, java.util.function.Function<ClientState,java.util.Set<T>> warnedValues, java.util.function.Function<ClientState,java.util.Set<T>> ignoredValues, java.util.function.Function<ClientState,java.util.Set<T>> disallowedValues, java.lang.String what)
Creates a new values guardrail. -
Uses of ClientState in org.apache.cassandra.locator
Methods in org.apache.cassandra.locator with parameters of type ClientState Modifier and Type Method Description void
AbstractReplicationStrategy. maybeWarnOnOptions(ClientState state)
void
NetworkTopologyStrategy. maybeWarnOnOptions(ClientState state)
void
SimpleStrategy. maybeWarnOnOptions(ClientState state)
static void
AbstractReplicationStrategy. validateReplicationStrategy(java.lang.String keyspaceName, java.lang.Class<? extends AbstractReplicationStrategy> strategyClass, TokenMetadata tokenMetadata, IEndpointSnitch snitch, java.util.Map<java.lang.String,java.lang.String> strategyOptions, ClientState state)
-
Uses of ClientState in org.apache.cassandra.schema
Methods in org.apache.cassandra.schema with parameters of type ClientState Modifier and Type Method Description void
KeyspaceParams. validate(java.lang.String name, ClientState state)
void
ReplicationParams. validate(java.lang.String name, ClientState state)
-
Uses of ClientState in org.apache.cassandra.service
Methods in org.apache.cassandra.service that return ClientState Modifier and Type Method Description ClientState
ClientState. cloneWithKeyspaceIfSet(java.lang.String keyspace)
Clone this ClientState object, but use the provided keyspace instead of the keyspace in this ClientState object.static ClientState
ClientState. forExternalCalls(java.net.SocketAddress remoteAddress)
static ClientState
ClientState. forInternalCalls()
static ClientState
ClientState. forInternalCalls(java.lang.String keyspace)
ClientState
QueryState. getClientState()
Methods in org.apache.cassandra.service with parameters of type ClientState 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, 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)
PartitionUpdate
CASRequest. makeUpdates(FilteredPartition current, ClientState clientState, Ballot ballot)
The updates to perform of a CAS success.Constructors in org.apache.cassandra.service with parameters of type ClientState Constructor Description ClientState(ClientState source)
QueryState(ClientState clientState)
QueryState(ClientState clientState, long timestamp, long nowInSeconds)
-
Uses of ClientState in org.apache.cassandra.service.pager
Methods in org.apache.cassandra.service.pager with parameters of type ClientState Modifier and Type Method Description PartitionIterator
AggregationQueryPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, long queryStartNanoTime)
PartitionIterator
MultiPartitionPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, long queryStartNanoTime)
PartitionIterator
QueryPager. fetchPage(int pageSize, ConsistencyLevel consistency, ClientState clientState, long queryStartNanoTime)
Fetches the next page.Constructors in org.apache.cassandra.service.pager with parameters of type ClientState Constructor Description AggregationPartitionIterator(int pageSize, ConsistencyLevel consistency, ClientState clientState, long queryStartNanoTime)
GroupByPartitionIterator(int pageSize, ConsistencyLevel consistency, ClientState clientState, long queryStartNanoTime)
-
Uses of ClientState in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos with parameters of type ClientState 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)
-
Uses of ClientState in org.apache.cassandra.transport
Methods in org.apache.cassandra.transport that return ClientState Modifier and Type Method Description ClientState
ServerConnection. getClientState()
-