| Modifier and Type | Method and Description | 
|---|---|
| Selector.Factory | ColumnDefinition. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| void | CFMetaData. renameColumn(ColumnIdentifier from,
            ColumnIdentifier to) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | UpdateParameters. addCell(ColumnDefinition column,
       java.nio.ByteBuffer value) | 
| void | UpdateParameters. addCell(ColumnDefinition column,
       CellPath path,
       java.nio.ByteBuffer value) | 
| void | UpdateParameters. addCounter(ColumnDefinition column,
          long increment) | 
| void | UpdateParameters. addCounter(ColumnDefinition column,
          long increment,
          CellPath path) | 
| void | UpdateParameters. addTombstone(ColumnDefinition column) | 
| void | UpdateParameters. addTombstone(ColumnDefinition column,
            CellPath path) | 
| abstract boolean | ColumnCondition.Bound. appliesTo(Row row)Validates whether this condition applies to  current. | 
| boolean | ColumnCondition.CollectionInBound. appliesTo(Row row) | 
| boolean | ColumnCondition.UDTInBound. appliesTo(Row row) | 
| ColumnCondition.Bound | ColumnCondition. bind(QueryOptions options) | 
| Constants.Value | Constants.Marker. bind(QueryOptions options) | 
| Term.Terminal | Lists.DelayedValue. bind(QueryOptions options) | 
| Term.Terminal | Lists.Marker. bind(QueryOptions options) | 
| Term.Terminal | Maps.DelayedValue. bind(QueryOptions options) | 
| Term.Terminal | Maps.Marker. bind(QueryOptions options) | 
| Term.Terminal | Sets.DelayedValue. bind(QueryOptions options) | 
| Term.Terminal | Sets.Marker. bind(QueryOptions options) | 
| Term.Terminal | Term. bind(QueryOptions options)Bind the values in this term to the values contained in  values. | 
| Tuples.Value | Tuples.DelayedValue. bind(QueryOptions options) | 
| Tuples.Value | Tuples.Marker. bind(QueryOptions options) | 
| Tuples.InValue | Tuples.InMarker. bind(QueryOptions options) | 
| UserTypes.Value | UserTypes.DelayedValue. bind(QueryOptions options) | 
| Term.Terminal | UserTypes.Marker. bind(QueryOptions options) | 
| java.nio.ByteBuffer | Constants.Marker. bindAndGet(QueryOptions options) | 
| java.nio.ByteBuffer | Term. bindAndGet(QueryOptions options)A shorter for bind(values).get(). | 
| java.nio.ByteBuffer | Term.Terminal. bindAndGet(QueryOptions options) | 
| java.nio.ByteBuffer | Term.NonTerminal. bindAndGet(QueryOptions options) | 
| java.nio.ByteBuffer | Tuples.DelayedValue. bindAndGet(QueryOptions options) | 
| java.nio.ByteBuffer | UserTypes.DelayedValue. bindAndGet(QueryOptions options) | 
| void | CQLStatement. checkAccess(ClientState state)Perform any access verification necessary for the statement. | 
| protected boolean | ColumnCondition.Bound. compareWithOperator(Operator operator,
                   AbstractType<?> type,
                   java.nio.ByteBuffer value,
                   java.nio.ByteBuffer otherValue)Returns true if the operator is satisfied (i.e. | 
| void | Constants.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Adder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Substracter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Deleter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.SetterByIndex. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Appender. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Prepender. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Discarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.DiscarderByIndex. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.SetterByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.AdderByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.SubtracterByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.Putter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.DiscarderByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| abstract void | Operation. execute(DecoratedKey partitionKey,
       UpdateParameters params)Execute the operation. | 
| void | Sets.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.Adder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.Discarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.ElementDiscarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.SetterByField. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.DeleterByField. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | CQL3Type.Raw. freeze() | 
| static Lists.Value | Lists.Value. fromSerialized(java.nio.ByteBuffer value,
              ListType type,
              ProtocolVersion version) | 
| static Tuples.InValue | Tuples.InValue. fromSerialized(java.nio.ByteBuffer value,
              ListType type,
              QueryOptions options) | 
| static Maps.Value | Maps.Value. fromSerialized(java.nio.ByteBuffer value,
              MapType type,
              ProtocolVersion version) | 
| static Sets.Value | Sets.Value. fromSerialized(java.nio.ByteBuffer value,
              SetType type,
              ProtocolVersion version) | 
| static CQL3Type.Raw | CQL3Type.Raw. frozen(CQL3Type.Raw t) | 
| abstract java.nio.ByteBuffer | Term.Terminal. get(ProtocolVersion protocolVersion) | 
| Term | QueryOptions. getJsonColumnValue(int bindIndex,
                  ColumnIdentifier columnName,
                  java.util.Collection<ColumnDefinition> expectedReceivers)Returns the term corresponding to column  columnNamein the JSON value of bind indexbindIndex. | 
| long | Attributes. getTimestamp(long now,
            QueryOptions options) | 
| int | Attributes. getTimeToLive(QueryOptions options,
             CFMetaData metadata) | 
| protected boolean | ColumnCondition.Bound. isSatisfiedByValue(java.nio.ByteBuffer value,
                  Cell c,
                  AbstractType<?> type,
                  Operator operator) | 
| protected Restriction | MultiColumnRelation. newContainsRestriction(CFMetaData cfm,
                      VariableSpecifications boundNames,
                      boolean isKey) | 
| protected abstract Restriction | Relation. newContainsRestriction(CFMetaData cfm,
                      VariableSpecifications boundNames,
                      boolean isKey)Creates a new Contains restriction instance. | 
| protected Restriction | SingleColumnRelation. newContainsRestriction(CFMetaData cfm,
                      VariableSpecifications boundNames,
                      boolean isKey) | 
| protected Restriction | TokenRelation. newContainsRestriction(CFMetaData cfm,
                      VariableSpecifications boundNames,
                      boolean isKey) | 
| protected Restriction | MultiColumnRelation. newEQRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected abstract Restriction | Relation. newEQRestriction(CFMetaData cfm,
                VariableSpecifications boundNames)Creates a new EQ restriction instance. | 
| protected Restriction | SingleColumnRelation. newEQRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected Restriction | TokenRelation. newEQRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected Restriction | MultiColumnRelation. newINRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected abstract Restriction | Relation. newINRestriction(CFMetaData cfm,
                VariableSpecifications boundNames)Creates a new IN restriction instance. | 
| protected Restriction | SingleColumnRelation. newINRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected Restriction | TokenRelation. newINRestriction(CFMetaData cfm,
                VariableSpecifications boundNames) | 
| protected Restriction | MultiColumnRelation. newIsNotRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames) | 
| protected abstract Restriction | Relation. newIsNotRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames) | 
| protected Restriction | SingleColumnRelation. newIsNotRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames) | 
| protected Restriction | TokenRelation. newIsNotRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames) | 
| protected Restriction | MultiColumnRelation. newLikeRestriction(CFMetaData cfm,
                  VariableSpecifications boundNames,
                  Operator operator) | 
| protected abstract Restriction | Relation. newLikeRestriction(CFMetaData cfm,
                  VariableSpecifications boundNames,
                  Operator operator) | 
| protected Restriction | SingleColumnRelation. newLikeRestriction(CFMetaData cfm,
                  VariableSpecifications boundNames,
                  Operator operator) | 
| protected Restriction | TokenRelation. newLikeRestriction(CFMetaData cfm,
                  VariableSpecifications boundNames,
                  Operator operator) | 
| void | UpdateParameters. newRow(Clustering clustering) | 
| protected Restriction | MultiColumnRelation. newSliceRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames,
                   Bound bound,
                   boolean inclusive) | 
| protected abstract Restriction | Relation. newSliceRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames,
                   Bound bound,
                   boolean inclusive)Creates a new Slice restriction instance. | 
| protected Restriction | SingleColumnRelation. newSliceRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames,
                   Bound bound,
                   boolean inclusive) | 
| protected Restriction | TokenRelation. newSliceRestriction(CFMetaData cfm,
                   VariableSpecifications boundNames,
                   Bound bound,
                   boolean inclusive) | 
| Operation | Operation.RawUpdate. prepare(CFMetaData cfm,
       ColumnDefinition receiver)This method validates the operation (i.e. | 
| Operation | Operation.SetValue. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.SetElement. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.SetField. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.ElementAddition. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.ElementSubtraction. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.Addition. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.Substraction. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| Operation | Operation.Prepend. prepare(CFMetaData cfm,
       ColumnDefinition receiver) | 
| ColumnCondition | ColumnCondition.Raw. prepare(java.lang.String keyspace,
       ColumnDefinition receiver,
       CFMetaData cfm) | 
| Operation | Operation.RawDeletion. prepare(java.lang.String keyspace,
       ColumnDefinition receiver,
       CFMetaData cfm)This method validates the operation (i.e. | 
| Operation | Operation.ColumnDeletion. prepare(java.lang.String keyspace,
       ColumnDefinition receiver,
       CFMetaData cfm) | 
| Operation | Operation.ElementDeletion. prepare(java.lang.String keyspace,
       ColumnDefinition receiver,
       CFMetaData cfm) | 
| Operation | Operation.FieldDeletion. prepare(java.lang.String keyspace,
       ColumnDefinition receiver,
       CFMetaData cfm) | 
| Term.NonTerminal | AbstractMarker.Raw. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term.NonTerminal | AbstractMarker.MultiColumnRaw. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| AbstractMarker | AbstractMarker.INRaw. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Constants.Value | Constants.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term | Lists.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term | Maps.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term | Sets.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| abstract Term | Term.Raw. prepare(java.lang.String keyspace,
       ColumnSpecification receiver)This method validates this RawTerm is valid for provided column
 specification and "prepare" this RawTerm, returning the resulting
 prepared Term. | 
| Term | Tuples.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term | TypeCast. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Term | UserTypes.Literal. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| abstract Term | Term.MultiColumnRaw. prepare(java.lang.String keyspace,
       java.util.List<? extends ColumnSpecification> receiver) | 
| Term | Tuples.Literal. prepare(java.lang.String keyspace,
       java.util.List<? extends ColumnSpecification> receivers) | 
| AbstractMarker | Tuples.Raw. prepare(java.lang.String keyspace,
       java.util.List<? extends ColumnSpecification> receivers) | 
| AbstractMarker | Tuples.INRaw. prepare(java.lang.String keyspace,
       java.util.List<? extends ColumnSpecification> receivers) | 
| Attributes | Attributes.Raw. prepare(java.lang.String ksName,
       java.lang.String cfName) | 
| abstract CQL3Type | CQL3Type.Raw. prepare(java.lang.String keyspace,
       Types udts) | 
| CQL3Type | CQL3Type.Raw. prepareInternal(java.lang.String keyspace,
               Types udts) | 
| protected java.util.List<ColumnDefinition> | MultiColumnRelation. receivers(CFMetaData cfm) | 
| Restriction | Relation. toRestriction(CFMetaData cfm,
             VariableSpecifications boundNames)Converts this  Relationinto aRestriction. | 
| protected Term | MultiColumnRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers,
      Term.Raw raw,
      java.lang.String keyspace,
      VariableSpecifications boundNames) | 
| protected abstract Term | Relation. toTerm(java.util.List<? extends ColumnSpecification> receivers,
      Term.Raw raw,
      java.lang.String keyspace,
      VariableSpecifications boundNames)Converts the specified  Rawinto aTerm. | 
| protected Term | SingleColumnRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers,
      Term.Raw raw,
      java.lang.String keyspace,
      VariableSpecifications boundNames) | 
| protected Term | TokenRelation. toTerm(java.util.List<? extends ColumnSpecification> receivers,
      Term.Raw raw,
      java.lang.String keyspace,
      VariableSpecifications boundNames) | 
| protected java.util.List<Term> | Relation. toTerms(java.util.List<? extends ColumnSpecification> receivers,
       java.util.List<? extends Term.Raw> raws,
       java.lang.String keyspace,
       VariableSpecifications boundNames)Converts the specified  Rawterms into aTerms. | 
| static void | QueryProcessor. validateKey(java.nio.ByteBuffer key) | 
| Constructor and Description | 
|---|
| UpdateParameters(CFMetaData metadata,
                PartitionColumns updatedColumns,
                QueryOptions options,
                long timestamp,
                int ttl,
                java.util.Map<DecoratedKey,Partition> prefetchedRows) | 
| Modifier and Type | Method and Description | 
|---|---|
| static UDAggregate | UDAggregate. createBroken(FunctionName name,
            java.util.List<AbstractType<?>> argTypes,
            AbstractType<?> returnType,
            java.nio.ByteBuffer initcond,
            InvalidRequestException reason) | 
| static UDFunction | UDFunction. createBrokenFunction(FunctionName name,
                    java.util.List<ColumnIdentifier> argNames,
                    java.util.List<AbstractType<?>> argTypes,
                    AbstractType<?> returnType,
                    boolean calledOnNullInput,
                    java.lang.String language,
                    java.lang.String body,
                    InvalidRequestException reason)It can happen that a function has been declared (is listed in the scheam) but cannot
 be loaded (maybe only on some nodes). | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AggregateFunction.Aggregate. addInput(ProtocolVersion protocolVersion,
        java.util.List<java.nio.ByteBuffer> values)Adds the specified input to this aggregate. | 
| Term.Terminal | FunctionCall. bind(QueryOptions options) | 
| java.nio.ByteBuffer | FunctionCall. bindAndGet(QueryOptions options) | 
| java.nio.ByteBuffer | AggregateFunction.Aggregate. compute(ProtocolVersion protocolVersion)Computes and returns the aggregate current value. | 
| static UDAggregate | UDAggregate. create(Functions functions,
      FunctionName name,
      java.util.List<AbstractType<?>> argTypes,
      AbstractType<?> returnType,
      FunctionName stateFunc,
      FunctionName finalFunc,
      AbstractType<?> stateType,
      java.nio.ByteBuffer initcond) | 
| java.nio.ByteBuffer | ScalarFunction. execute(ProtocolVersion protocolVersion,
       java.util.List<java.nio.ByteBuffer> parameters)Applies this function to the specified parameter. | 
| java.nio.ByteBuffer | ToJsonFct. execute(ProtocolVersion protocolVersion,
       java.util.List<java.nio.ByteBuffer> parameters) | 
| java.nio.ByteBuffer | TokenFct. execute(ProtocolVersion protocolVersion,
       java.util.List<java.nio.ByteBuffer> parameters) | 
| static Function | FunctionResolver. get(java.lang.String keyspace,
   FunctionName name,
   java.util.List<? extends AssignmentTestable> providedArgs,
   java.lang.String receiverKs,
   java.lang.String receiverCf,
   AbstractType<?> receiverType) | 
| static ToJsonFct | ToJsonFct. getInstance(java.util.List<AbstractType<?>> argTypes) | 
| AggregateFunction.Aggregate | AggregateFunction. newAggregate()Creates a new  Aggregateinstance. | 
| AggregateFunction.Aggregate | UDAggregate. newAggregate() | 
| Term | FunctionCall.Raw. prepare(java.lang.String keyspace,
       ColumnSpecification receiver) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SingleColumnRestriction.SuperColumnKeyEQRestriction. addRowFilterTo(RowFilter filter,
              SecondaryIndexManager indexManager,
              QueryOptions options) | 
| void | SingleColumnRestriction.SuperColumnKeyINRestriction. addRowFilterTo(RowFilter filter,
              SecondaryIndexManager indexManager,
              QueryOptions options) | 
| void | SingleColumnRestriction.SuperColumnKeySliceRestriction. addRowFilterTo(RowFilter filter,
              SecondaryIndexManager indexManager,
              QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | TokenRestriction.EQRestriction. bounds(Bound b,
      QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | TokenRestriction.SliceRestriction. bounds(Bound b,
      QueryOptions options) | 
| protected abstract org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions | TokenRestriction. doMergeWith(TokenRestriction otherRestriction)Merges this restriction with the specified  TokenRestriction. | 
| protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions | TokenRestriction.EQRestriction. doMergeWith(TokenRestriction otherRestriction) | 
| protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions | TokenRestriction.SliceRestriction. doMergeWith(TokenRestriction otherRestriction) | 
| abstract java.util.List<java.nio.ByteBuffer> | SingleColumnRestriction.SuperColumnKeyINRestriction. getValues(QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | SingleColumnRestriction.SuperColumnKeyINRestrictionWithMarkers. getValues(QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | SingleColumnRestriction.SuperColumnKeyINRestrictionWithValues. getValues(QueryOptions options) | 
| org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions | TokenRestriction. mergeWith(Restriction otherRestriction) | 
| java.util.List<java.nio.ByteBuffer> | TokenRestriction.EQRestriction. values(QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | TokenRestriction.SliceRestriction. values(QueryOptions options) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract void | Selector. addInput(ProtocolVersion protocolVersion,
        Selection.ResultSetBuilder rs)Add the current value from the specified  ResultSetBuilder. | 
| void | SimpleSelector. addInput(ProtocolVersion protocolVersion,
        Selection.ResultSetBuilder rs) | 
| void | TermSelector. addInput(ProtocolVersion protocolVersion,
        Selection.ResultSetBuilder rs) | 
| abstract java.nio.ByteBuffer | Selector. getOutput(ProtocolVersion protocolVersion)Returns the selector output. | 
| java.nio.ByteBuffer | SimpleSelector. getOutput(ProtocolVersion protocolVersion) | 
| java.nio.ByteBuffer | TermSelector. getOutput(ProtocolVersion protocolVersion) | 
| abstract Selector | Selector.Factory. newInstance(QueryOptions options)Creates a new  Selectorinstance. | 
| Selector.Factory | Selectable.WithTerm. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| protected abstract org.apache.cassandra.cql3.selection.Selection.Selectors | Selection. newSelectors(QueryOptions options) | 
| Modifier and Type | Method and Description | 
|---|---|
| static InvalidRequestException | RequestValidations. invalidRequest(java.lang.String messageTemplate,
              java.lang.Object... messageArgs)Returns an  InvalidRequestExceptionwith the specified message. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CQL3CasRequest. addConditions(Clustering clustering,
             java.util.Collection<ColumnCondition> conds,
             QueryOptions options) | 
| void | ModificationStatement. addConditions(Clustering clustering,
             CQL3CasRequest request,
             QueryOptions options) | 
| void | CQL3CasRequest. addExist(Clustering clustering) | 
| void | CQL3CasRequest. addNotExist(Clustering clustering) | 
| void | CreateTypeStatement. addToRawBuilder(Types.RawBuilder builder) | 
| void | DeleteStatement. addUpdateForKey(PartitionUpdate update,
               Clustering clustering,
               UpdateParameters params) | 
| Event.SchemaChange | AlterTypeStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | CreateTriggerStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | CreateTypeStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | DropIndexStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | DropTriggerStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | DropTypeStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| Event.SchemaChange | DropViewStatement. announceMigration(QueryState queryState,
                 boolean isLocalOnly) | 
| boolean | CQL3CasRequest. appliesTo(FilteredPartition current)Checks whether the conditions represented by this object applies provided the current state of the partition on
 which those conditions are. | 
| static ResultSet | ModificationStatement. buildCasResultSet(java.lang.String ksName,
                 java.lang.String tableName,
                 RowIterator partition,
                 java.lang.Iterable<ColumnDefinition> columnsWithConditions,
                 boolean isBatch,
                 QueryOptions options) | 
| java.util.List<java.nio.ByteBuffer> | ModificationStatement. buildPartitionKeyNames(QueryOptions options) | 
| void | AlterKeyspaceStatement. checkAccess(ClientState state) | 
| void | AlterTableStatement. checkAccess(ClientState state) | 
| void | AlterTypeStatement. checkAccess(ClientState state) | 
| void | AlterViewStatement. checkAccess(ClientState state) | 
| void | BatchStatement. checkAccess(ClientState state) | 
| void | CreateAggregateStatement. checkAccess(ClientState state) | 
| void | CreateFunctionStatement. checkAccess(ClientState state) | 
| void | CreateIndexStatement. checkAccess(ClientState state) | 
| void | CreateTableStatement. checkAccess(ClientState state) | 
| void | CreateTypeStatement. checkAccess(ClientState state) | 
| void | CreateViewStatement. checkAccess(ClientState state) | 
| void | DropAggregateStatement. checkAccess(ClientState state) | 
| void | DropFunctionStatement. checkAccess(ClientState state) | 
| void | DropIndexStatement. checkAccess(ClientState state) | 
| void | DropKeyspaceStatement. checkAccess(ClientState state) | 
| void | DropTableStatement. checkAccess(ClientState state) | 
| void | DropTypeStatement. checkAccess(ClientState state) | 
| void | DropViewStatement. checkAccess(ClientState state) | 
| void | ListRolesStatement. checkAccess(ClientState state) | 
| void | ModificationStatement. checkAccess(ClientState state) | 
| void | SelectStatement. checkAccess(ClientState state) | 
| void | TruncateStatement. checkAccess(ClientState state) | 
| static void | RequestValidations. checkBindValueSet(java.nio.ByteBuffer b,
                 java.lang.String messageTemplate,
                 java.lang.Object... messageArgs)Checks that the specified bind marker value is set to a meaningful value. | 
| static void | RequestValidations. checkContainsNoDuplicates(java.util.List<?> list,
                         java.lang.String message)Checks that the specified list does not contains duplicates. | 
| static <E> void | RequestValidations. checkContainsOnly(java.util.List<E> list,
                 java.util.List<E> expectedElements,
                 java.lang.String message)Checks that the specified list contains only the specified elements. | 
| static void | RequestValidations. checkFalse(boolean expression,
          java.lang.String message)Checks that the specified expression is  false. | 
| static void | RequestValidations. checkFalse(boolean expression,
          java.lang.String messageTemplate,
          java.lang.Object... messageArgs)Checks that the specified expression is  false. | 
| static void | CreateTypeStatement. checkForDuplicateNames(UserType type) | 
| static <T> T | RequestValidations. checkNotNull(T object,
            java.lang.String messageTemplate,
            java.lang.Object... messageArgs)Checks that the specified object is NOT  null. | 
| static <T> T | RequestValidations. checkNull(T object,
         java.lang.String message)Checks that the specified object is  null. | 
| static <T> T | RequestValidations. checkNull(T object,
         java.lang.String messageTemplate,
         java.lang.Object... messageArgs)Checks that the specified object is  null. | 
| static void | RequestValidations. checkTrue(boolean expression,
         java.lang.String message)Checks that the specified expression is  true. | 
| static void | RequestValidations. checkTrue(boolean expression,
         java.lang.String messageTemplate,
         java.lang.Object... messageArgs)Checks that the specified expression is  true. | 
| java.util.NavigableSet<Clustering> | ModificationStatement. createClustering(QueryOptions options) | 
| UserType | CreateTypeStatement. createType() | 
| ResultMessage | TruncateStatement. execute(QueryState state,
       QueryOptions options,
       long queryStartNanoTime) | 
| ResultMessage | UseStatement. execute(QueryState state,
       QueryOptions options,
       long queryStartNanoTime) | 
| ResultMessage | UseStatement. executeInternal(QueryState state,
               QueryOptions options) | 
| RowFilter | SelectStatement. getRowFilter(QueryOptions options)May be used by custom QueryHandler implementations | 
| long | ModificationStatement. getTimestamp(long now,
            QueryOptions options) | 
| int | ModificationStatement. getTimeToLive(QueryOptions options) | 
| protected abstract UserType | AlterTypeStatement. makeUpdatedType(UserType toUpdate,
               KeyspaceMetadata ksm) | 
| PartitionUpdate | CQL3CasRequest. makeUpdates(FilteredPartition current) | 
| static IResource | AuthorizationStatement. maybeCorrectResource(IResource resource,
                    ClientState state) | 
| ParsedStatement.Prepared | SelectStatement.RawStatement. prepare(boolean forView,
       ClientState clientState) | 
| ParsedStatement.Prepared | BatchStatement.Parsed. prepare(ClientState clientState) | 
| ParsedStatement.Prepared | CreateFunctionStatement. prepare(ClientState clientState) | 
| ParsedStatement.Prepared | DropFunctionStatement. prepare(ClientState clientState) | 
| ParsedStatement.Prepared | SelectStatement.RawStatement. prepare(ClientState clientState) | 
| ParsedStatement.Prepared | TruncateStatement. prepare(ClientState clientState) | 
| ParsedStatement.Prepared | UseStatement. prepare(ClientState clientState) | 
| void | AlterTypeStatement. prepareKeyspace(ClientState state) | 
| void | BatchStatement.Parsed. prepareKeyspace(ClientState state) | 
| void | CFStatement. prepareKeyspace(ClientState state) | 
| void | CreateAggregateStatement. prepareKeyspace(ClientState state) | 
| void | CreateFunctionStatement. prepareKeyspace(ClientState state) | 
| void | CreateTypeStatement. prepareKeyspace(ClientState state) | 
| void | DropAggregateStatement. prepareKeyspace(ClientState state) | 
| void | DropFunctionStatement. prepareKeyspace(ClientState state) | 
| void | DropTypeStatement. prepareKeyspace(ClientState state) | 
| void | SchemaAlteringStatement. prepareKeyspace(ClientState state) | 
| ResultSet | SelectStatement. process(PartitionIterator partitions,
       int nowInSec) | 
| void | BatchStatement. validate() | 
| void | BatchStatement. validate(ClientState state) | 
| void | CreateAggregateStatement. validate(ClientState state) | 
| void | CreateFunctionStatement. validate(ClientState state) | 
| void | ListRolesStatement. validate(ClientState state) | 
| void | ModificationStatement. validate(ClientState state) | 
| void | SelectStatement. validate(ClientState state) | 
| void | TruncateStatement. validate(ClientState state) | 
| void | UseStatement. validate(ClientState state) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | KeyspaceNotDefinedException | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | ExpirationDateOverflowHandling. maybeApplyExpirationDateOverflowPolicy(CFMetaData metadata,
                                      int ttl,
                                      boolean isDefaultTTL) | 
| void | ConsistencyLevel. validateCounterForWrite(CFMetaData metadata) | 
| void | ConsistencyLevel. validateForCas() | 
| void | ConsistencyLevel. validateForCasCommit(java.lang.String keyspaceName) | 
| void | ConsistencyLevel. validateForRead(java.lang.String keyspaceName) | 
| void | ConsistencyLevel. validateForWrite(java.lang.String keyspaceName) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Index. validate(PartitionUpdate update)Called at write time to ensure that values present in the update
 are valid according to the rules of all registered indexes which
 will process it. | 
| void | SecondaryIndexManager. validate(PartitionUpdate update)Called at write time to ensure that values present in the update
 are valid according to the rules of all registered indexes which
 will process it. | 
| default void | Index. validate(ReadCommand command)Used to validate the various parameters of a supplied ReadCommand,
 this is called prior to execution. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CassandraIndex. validate(PartitionUpdate update) | 
| void | CassandraIndex. validate(ReadCommand command) | 
| Modifier and Type | Method and Description | 
|---|---|
| Index.Searcher | SASIIndex. searcherFor(ReadCommand command) | 
| void | SASIIndex. validate(PartitionUpdate update) | 
| Modifier and Type | Method and Description | 
|---|---|
| CQLSSTableWriter | CQLSSTableWriter. addRow(java.util.List<java.lang.Object> values)Adds a new row to the writer. | 
| CQLSSTableWriter | CQLSSTableWriter. addRow(java.util.Map<java.lang.String,java.lang.Object> values)Adds a new row to the writer. | 
| CQLSSTableWriter | CQLSSTableWriter. addRow(java.lang.Object... values)Adds a new row to the writer. | 
| CQLSSTableWriter | CQLSSTableWriter. rawAddRow(java.nio.ByteBuffer... values)Adds a new row to the writer given already serialized values. | 
| CQLSSTableWriter | CQLSSTableWriter. rawAddRow(java.util.List<java.nio.ByteBuffer> values)Adds a new row to the writer given already serialized values. | 
| CQLSSTableWriter | CQLSSTableWriter. rawAddRow(java.util.Map<java.lang.String,java.nio.ByteBuffer> values)Adds a new row to the writer given already serialized values. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | CASRequest. appliesTo(FilteredPartition current)Returns whether the provided CF, that represents the values fetched using the
 readFilter(), match the CAS conditions this object stands for. | 
| static RowIterator | StorageProxy. cas(java.lang.String keyspaceName,
   java.lang.String cfName,
   DecoratedKey key,
   CASRequest request,
   ConsistencyLevel consistencyForPaxos,
   ConsistencyLevel consistencyForCommit,
   ClientState state,
   long queryStartNanoTime)Apply @param updates if and only if the current values in the row for @param key
 match the provided @param conditions. | 
| java.util.List<TokenRange> | StorageService. describeLocalRing(java.lang.String keyspace)The same as  describeRing(String)but considers only the part of the ring formed by nodes in the local DC. | 
| java.util.List<TokenRange> | StorageService. describeRing(java.lang.String keyspace)The TokenRange for a given keyspace. | 
| java.lang.String | ClientState. getKeyspace() | 
| void | ClientState. hasColumnFamilyAccess(CFMetaData cfm,
                     Permission perm) | 
| void | ClientState. hasColumnFamilyAccess(java.lang.String keyspace,
                     java.lang.String columnFamily,
                     Permission perm) | 
| void | ClientState. hasKeyspaceAccess(java.lang.String keyspace,
                 Permission perm) | 
| PartitionUpdate | CASRequest. makeUpdates(FilteredPartition current)The updates to perform of a CAS success. | 
| static void | StorageProxy. mutateWithTriggers(java.util.Collection<? extends IMutation> mutations,
                  ConsistencyLevel consistencyLevel,
                  boolean mutateAtomically,
                  long queryStartNanoTime) | 
| static PartitionIterator | StorageProxy. read(SinglePartitionReadCommand.Group group,
    ConsistencyLevel consistencyLevel,
    ClientState state,
    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 PartitionIterator | StorageProxy. read(SinglePartitionReadCommand.Group group,
    ConsistencyLevel consistencyLevel,
    long queryStartNanoTime) | 
| static RowIterator | StorageProxy. readOne(SinglePartitionReadCommand command,
       ConsistencyLevel consistencyLevel,
       ClientState state,
       long queryStartNanoTime) | 
| static RowIterator | StorageProxy. readOne(SinglePartitionReadCommand command,
       ConsistencyLevel consistencyLevel,
       long queryStartNanoTime) | 
| void | ClientState. setKeyspace(java.lang.String ks) | 
| Modifier and Type | Method and Description | 
|---|---|
| static CFMetaData | ThriftConversion. fromThrift(CfDef cf_def) | 
| static CFMetaData | ThriftConversion. fromThriftForUpdate(CfDef cf_def,
                   CFMetaData toUpdate) | 
| protected PartitionIterator | CassandraServer. read(java.util.List<SinglePartitionReadCommand> commands,
    ConsistencyLevel consistency_level,
    ClientState cState,
    long queryStartNanoTime) | 
| static void | ThriftValidation. validateColumnData(CFMetaData metadata,
                  java.nio.ByteBuffer scName,
                  Column column)Validates the data part of the column (everything in the column object but the name, which is assumed to be valid) | 
| static CFMetaData | ThriftValidation. validateColumnFamily(java.lang.String keyspaceName,
                    java.lang.String cfName) | 
| static CFMetaData | ThriftValidation. validateColumnFamily(java.lang.String keyspaceName,
                    java.lang.String cfName,
                    boolean isCommutativeOp) | 
| static CFMetaData | ThriftValidation. validateColumnFamilyWithCompactMode(java.lang.String keyspaceName,
                                   java.lang.String cfName,
                                   boolean noCompactMode) | 
| static void | ThriftValidation. validateColumnNames(CFMetaData metadata,
                   ColumnParent column_parent,
                   java.lang.Iterable<java.nio.ByteBuffer> column_names) | 
| static void | ThriftValidation. validateColumnOrSuperColumn(CFMetaData metadata,
                           ColumnOrSuperColumn cosc) | 
| static void | ThriftValidation. validateColumnParent(CFMetaData metadata,
                    ColumnParent column_parent) | 
| static void | ThriftValidation. validateColumnPath(CFMetaData metadata,
                  ColumnPath column_path)validates all parts of the path to the column, including the column name | 
| static void | ThriftValidation. validateDeletion(CFMetaData metadata,
                Deletion del) | 
| static boolean | ThriftValidation. validateFilterClauses(CFMetaData metadata,
                     java.util.List<IndexExpression> index_clause) | 
| static void | ThriftValidation. validateIndexClauses(CFMetaData metadata,
                    IndexClause index_clause) | 
| static void | ThriftValidation. validateKey(CFMetaData metadata,
           java.nio.ByteBuffer key) | 
| static void | ThriftValidation. validateKeyRange(CFMetaData metadata,
                java.nio.ByteBuffer superColumn,
                KeyRange range) | 
| static void | ThriftValidation. validateKeyspaceNotSystem(java.lang.String modifiedKeyspace) | 
| static void | ThriftValidation. validateKeyspaceNotYetExisting(java.lang.String newKsName) | 
| static void | ThriftValidation. validateMutation(CFMetaData metadata,
                Mutation mut) | 
| static void | ThriftValidation. validatePredicate(CFMetaData metadata,
                 ColumnParent column_parent,
                 SlicePredicate predicate) | 
| static void | ThriftValidation. validateRange(CFMetaData metadata,
             ColumnParent column_parent,
             SliceRange range) | 
| static void | ThriftValidation. validateSlicePredicate(CFMetaData metadata,
                      java.nio.ByteBuffer scName,
                      SlicePredicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.Collection<Mutation> | TriggerExecutor. execute(java.util.Collection<? extends IMutation> mutations)Takes a collection of mutations and possibly augments it by adding extra mutations
 generated by configured triggers. | 
| PartitionUpdate | TriggerExecutor. execute(PartitionUpdate updates)Augment a partition update by executing triggers to generate an intermediate
 set of mutations, then merging the update from each mutation with those
 supplied. | 
Copyright © 2018 The Apache Software Foundation