| Modifier and Type | Field and Description | 
|---|---|
| CFMetaData | ViewDefinition. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | CFMetaData. addColumnDefinition(ColumnDefinition def) | 
| CFMetaData | CFMetaData. addOrReplaceColumnDefinition(ColumnDefinition def) | 
| CFMetaData | CFMetaData. asNonCompact()Returns a cached non-compact version of this table. | 
| CFMetaData | ViewDefinition. baseTableMetadata() | 
| CFMetaData | CFMetaData. bloomFilterFpChance(double prop) | 
| CFMetaData | CFMetaData.Builder. build() | 
| CFMetaData | CFMetaData. caching(CachingParams prop) | 
| CFMetaData | CFMetaData. comment(java.lang.String prop) | 
| CFMetaData | CFMetaData. compaction(CompactionParams prop) | 
| static CFMetaData | CFMetaData. compile(java.lang.String cql,
       java.lang.String keyspace) | 
| CFMetaData | CFMetaData. compression(CompressionParams prop) | 
| CFMetaData | CFMetaData. copy() | 
| CFMetaData | CFMetaData. copy(IPartitioner partitioner) | 
| CFMetaData | CFMetaData. copy(java.util.UUID newCfId)Clones the CFMetaData, but sets a different cfId | 
| static CFMetaData | CFMetaData. copyOpts(CFMetaData newCFMD,
        CFMetaData oldCFMD) | 
| CFMetaData | CFMetaData. crcCheckChance(double prop) | 
| static CFMetaData | CFMetaData. create(java.lang.String ksName,
      java.lang.String name,
      java.util.UUID cfId,
      boolean isDense,
      boolean isCompound,
      boolean isSuper,
      boolean isCounter,
      boolean isView,
      java.util.List<ColumnDefinition> columns,
      IPartitioner partitioner) | 
| static CFMetaData | CFMetaData. createFake(java.lang.String keyspace,
          java.lang.String name)There is a couple of places in the code where we need a CFMetaData object and don't have one readily available
 and know that only the keyspace and name matter. | 
| CFMetaData | CFMetaData. dcLocalReadRepairChance(double prop) | 
| CFMetaData | CFMetaData. defaultTimeToLive(int prop) | 
| CFMetaData | CFMetaData.Serializer. deserialize(DataInputPlus in,
           int version) | 
| CFMetaData | CFMetaData. droppedColumns(java.util.Map<java.nio.ByteBuffer,CFMetaData.DroppedColumn> cols) | 
| CFMetaData | CFMetaData. extensions(java.util.Map<java.lang.String,java.nio.ByteBuffer> extensions) | 
| CFMetaData | CFMetaData. gcGraceSeconds(int prop) | 
| CFMetaData | Schema. getCFMetaData(Descriptor descriptor) | 
| CFMetaData | Schema. getCFMetaData(java.lang.String keyspaceName,
             java.lang.String cfName)Given a keyspace name and column family name, get the column family
 meta data. | 
| CFMetaData | Schema. getCFMetaData(java.util.UUID cfId)Get ColumnFamily metadata by its identifier | 
| CFMetaData | CFMetaData. indexes(Indexes indexes) | 
| CFMetaData | CFMetaData. maxIndexInterval(int prop) | 
| CFMetaData | CFMetaData. memtableFlushPeriod(int prop) | 
| CFMetaData | CFMetaData. minIndexInterval(int prop) | 
| CFMetaData | CFMetaData. params(TableParams params) | 
| CFMetaData | CFMetaData. readRepairChance(double prop) | 
| CFMetaData | CFMetaData. reloadIndexMetadataProperties(CFMetaData parent) | 
| CFMetaData | CFMetaData. speculativeRetry(SpeculativeRetryParam prop) | 
| CFMetaData | CFMetaData. triggers(Triggers prop) | 
| CFMetaData | CFMetaData. validate() | 
| Modifier and Type | Method and Description | 
|---|---|
| java.lang.Iterable<CFMetaData> | Schema. getTablesAndViews(java.lang.String keyspaceName)Get metadata about keyspace inner ColumnFamilies | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Schema. addTable(CFMetaData cfm) | 
| boolean | CFMetaData. apply(CFMetaData cfm)Updates CFMetaData in-place to match cfm | 
| static ColumnDefinition | ColumnDefinition. clusteringDef(CFMetaData cfm,
             java.nio.ByteBuffer name,
             AbstractType<?> type,
             int position) | 
| static CFMetaData | CFMetaData. copyOpts(CFMetaData newCFMD,
        CFMetaData oldCFMD) | 
| abstract ColumnIdentifier | ColumnDefinition.Raw. getIdentifier(CFMetaData cfm)Get the identifier corresponding to this raw column, without assuming this is an
 existing column (unlike  ColumnDefinition.Raw.prepare(org.apache.cassandra.config.CFMetaData)). | 
| void | Schema. load(CFMetaData cfm)Load individual ColumnFamily Definition to the schema
 (to make ColumnFamily lookup faster) | 
| Selector.Factory | ColumnDefinition. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| static ColumnDefinition | ColumnDefinition. partitionKeyDef(CFMetaData cfm,
               java.nio.ByteBuffer name,
               AbstractType<?> type,
               int position) | 
| abstract ColumnDefinition | ColumnDefinition.Raw. prepare(CFMetaData cfm) | 
| static ColumnDefinition | ColumnDefinition. regularDef(CFMetaData cfm,
          java.nio.ByteBuffer name,
          AbstractType<?> type) | 
| CFMetaData | CFMetaData. reloadIndexMetadataProperties(CFMetaData parent) | 
| void | CFMetaData.Serializer. serialize(CFMetaData metadata,
         DataOutputPlus out,
         int version) | 
| long | CFMetaData.Serializer. serializedSize(CFMetaData metadata,
              int version) | 
| static ColumnDefinition | ColumnDefinition. staticDef(CFMetaData cfm,
         java.nio.ByteBuffer name,
         AbstractType<?> type) | 
| void | Schema. unload(CFMetaData cfm)Used for ColumnFamily data eviction out from the schema | 
| void | Schema. updateTable(CFMetaData table) | 
| void | CFMetaData. validateCompatibility(CFMetaData cfm) | 
| Constructor and Description | 
|---|
| ColumnDefinition(CFMetaData cfm,
                java.nio.ByteBuffer name,
                AbstractType<?> type,
                int position,
                ColumnDefinition.Kind kind) | 
| ViewDefinition(java.lang.String ksName,
              java.lang.String viewName,
              java.util.UUID baseTableId,
              java.lang.String baseTableName,
              boolean includeAllColumns,
              SelectStatement.RawStatement select,
              java.lang.String whereClause,
              CFMetaData metadata) | 
| Modifier and Type | Field and Description | 
|---|---|
| CFMetaData | UpdateParameters. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| static UntypedResultSet.Row | UntypedResultSet.Row. fromInternalRow(CFMetaData metadata,
               DecoratedKey key,
               Row row) | 
| static ColumnFilter | SuperColumnCompatibility. getColumnFilter(CFMetaData cfm,
               QueryOptions queryOptions,
               SuperColumnCompatibility.SuperColumnRestrictions restrictions)For _dense_ SuperColumn Families, the supercolumn key column has to be translated to the collection subselection
 query in order to avoid reading an entire collection and then filtering out the results. | 
| short[] | VariableSpecifications. getPartitionKeyBindIndexes(CFMetaData cfm)Returns an array with the same length as the number of partition key columns for the table corresponding
 to cfm. | 
| static ColumnDefinition | SuperColumnCompatibility. getSuperCfKeyColumn(CFMetaData cfm,
                   java.util.List<ColumnDefinition> clusteringColumns,
                   CompactTables.DefaultNames defaultNames)Find a SuperColumn key column if it's available (for example, when it was renamed) or create one with a default name. | 
| static ColumnDefinition | SuperColumnCompatibility. getSuperCfValueColumn(CFMetaData cfm,
                     PartitionColumns partitionColumns,
                     ColumnDefinition superCfKeyColumn,
                     CompactTables.DefaultNames defaultNames)Find a SuperColumn value column if it's available (for example, when it was renamed) or create one with a default name. | 
| int | Attributes. getTimeToLive(QueryOptions options,
             CFMetaData metadata) | 
| 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) | 
| 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) | 
| Json.Prepared | Json.Raw. prepareAndCollectMarkers(CFMetaData metadata,
                        java.util.Collection<ColumnDefinition> receivers,
                        VariableSpecifications boundNames) | 
| Json.Prepared | Json.Literal. prepareAndCollectMarkers(CFMetaData metadata,
                        java.util.Collection<ColumnDefinition> receivers,
                        VariableSpecifications boundNames) | 
| Json.Prepared | Json.Marker. prepareAndCollectMarkers(CFMetaData metadata,
                        java.util.Collection<ColumnDefinition> receivers,
                        VariableSpecifications boundNames) | 
| static WhereClause | SuperColumnCompatibility. prepareDeleteOperations(CFMetaData cfm,
                       WhereClause whereClause,
                       VariableSpecifications boundNames,
                       Operations operations)For _dense_ SuperColumn Families. | 
| static void | SuperColumnCompatibility. prepareInsertJSONOperations(CFMetaData cfm,
                           java.util.List<ColumnDefinition> defs,
                           VariableSpecifications boundNames,
                           Json.Prepared prepared,
                           WhereClause.Builder whereClause,
                           Operations operations)For _dense_ SuperColumn Families. | 
| static void | SuperColumnCompatibility. prepareInsertOperations(CFMetaData cfm,
                       java.util.List<ColumnDefinition.Raw> columnNames,
                       WhereClause.Builder whereClause,
                       java.util.List<Term.Raw> columnValues,
                       VariableSpecifications boundNames,
                       Operations operations)For _dense_ SuperColumn Families. | 
| static WhereClause | SuperColumnCompatibility. prepareUpdateOperations(CFMetaData cfm,
                       WhereClause whereClause,
                       java.util.List<Pair<ColumnDefinition.Raw,Operation.RawUpdate>> updates,
                       VariableSpecifications boundNames,
                       Operations operations)For _dense_ SuperColumn Families. | 
| static void | SuperColumnCompatibility. processPartition(CFMetaData cfm,
                Selection selection,
                RowIterator partition,
                Selection.ResultSetBuilder result,
                ProtocolVersion protocolVersion,
                SuperColumnCompatibility.SuperColumnRestrictions restrictions,
                QueryOptions queryOptions)For _dense_ SuperColumn Families. | 
| static Conditions | SuperColumnCompatibility. rebuildLWTColumnConditions(Conditions conditions,
                          CFMetaData cfm,
                          WhereClause whereClause)Rebuilds LWT conditions on SuperColumn _value_ column. | 
| protected java.util.List<ColumnDefinition> | MultiColumnRelation. receivers(CFMetaData cfm) | 
| Restriction | Relation. toRestriction(CFMetaData cfm,
             VariableSpecifications boundNames)Converts this  Relationinto aRestriction. | 
| Constructor and Description | 
|---|
| UpdateParameters(CFMetaData metadata,
                PartitionColumns updatedColumns,
                QueryOptions options,
                long timestamp,
                int ttl,
                java.util.Map<DecoratedKey,Partition> prefetchedRows) | 
| Constructor and Description | 
|---|
| TokenFct(CFMetaData cfm) | 
| Modifier and Type | Field and Description | 
|---|---|
| CFMetaData | StatementRestrictions. cfmThe Column Family meta data | 
| protected CFMetaData | TokenRestriction. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CustomIndexExpression. addToRowFilter(RowFilter filter,
              CFMetaData cfm,
              QueryOptions options) | 
| static StatementRestrictions | StatementRestrictions. empty(StatementType type,
     CFMetaData cfm)Creates a new empty  StatementRestrictions. | 
| boolean | TokenRestriction. hasUnrestrictedPartitionKeyComponents(CFMetaData cfm) | 
| boolean | TokenRestriction. needFiltering(CFMetaData cfm) | 
| void | CustomIndexExpression. prepareValue(CFMetaData cfm,
            AbstractType<?> expressionType,
            VariableSpecifications boundNames) | 
| Constructor and Description | 
|---|
| EQRestriction(CFMetaData cfm,
             java.util.List<ColumnDefinition> columnDefs,
             Term value) | 
| SliceRestriction(CFMetaData cfm,
                java.util.List<ColumnDefinition> columnDefs,
                Bound bound,
                boolean inclusive,
                Term term) | 
| StatementRestrictions(StatementType type,
                     CFMetaData cfm,
                     WhereClause whereClause,
                     VariableSpecifications boundNames,
                     boolean selectsOnlyStaticColumns,
                     boolean selectsComplexColumn,
                     boolean allowFiltering,
                     boolean forView) | 
| TokenRestriction(CFMetaData metadata,
                java.util.List<ColumnDefinition> columnDefs)Creates a new  TokenRestrictionthat apply to the specified columns. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Selection | Selection. forColumns(CFMetaData cfm,
          java.util.List<ColumnDefinition> columns) | 
| static Selection | Selection. fromSelectors(CFMetaData cfm,
             java.util.List<RawSelector> rawSelectors,
             VariableSpecifications boundNames,
             boolean hasGroupBy) | 
| ColumnSpecification | Selector.Factory. getColumnSpecification(CFMetaData cfm)Returns the column specification corresponding to the output value of the selector instances created by
 this factory. | 
| Selector.Factory | Selectable. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WithTerm. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WritetimeOrTTL. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WithFunction. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WithToJSonFunction. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WithCast. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| Selector.Factory | Selectable.WithFieldSelection. newSelectorFactory(CFMetaData cfm,
                  AbstractType<?> expectedType,
                  java.util.List<ColumnDefinition> defs,
                  VariableSpecifications boundNames) | 
| abstract Selectable | Selectable.Raw. prepare(CFMetaData cfm) | 
| Selectable | Selectable.WithTerm.Raw. prepare(CFMetaData cfm) | 
| Selectable.WritetimeOrTTL | Selectable.WritetimeOrTTL.Raw. prepare(CFMetaData cfm) | 
| Selectable | Selectable.WithFunction.Raw. prepare(CFMetaData cfm) | 
| Selectable.WithCast | Selectable.WithCast.Raw. prepare(CFMetaData cfm) | 
| Selectable.WithFieldSelection | Selectable.WithFieldSelection.Raw. prepare(CFMetaData cfm) | 
| static java.util.List<Selectable> | RawSelector. toSelectables(java.util.List<RawSelector> raws,
             CFMetaData cfm)Converts the specified list of  RawSelectors into a list ofSelectables. | 
| static Selection | Selection. wildcard(CFMetaData cfm) | 
| Constructor and Description | 
|---|
| Selection(CFMetaData cfm,
         java.util.List<ColumnDefinition> columns,
         SelectionColumnMapping columnMapping,
         boolean collectTimestamps,
         boolean collectTTLs) | 
| Modifier and Type | Field and Description | 
|---|---|
| CFMetaData | CQL3CasRequest. cfm | 
| CFMetaData | ModificationStatement. cfm | 
| CFMetaData | SelectStatement. cfm | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | CreateTableStatement. getCFMetaData()Returns a CFMetaData instance based on the parameters parsed from this
  CREATEstatement, or defaults where applicable. | 
| Modifier and Type | Method and Description | 
|---|---|
| java.lang.String | IndexTarget. asCqlString(CFMetaData cfm) | 
| protected static ColumnDefinition | ModificationStatement.Parsed. getColumnDefinition(CFMetaData cfm,
                   ColumnDefinition.Raw rawId)Retrieves the  ColumnDefinitioncorresponding to the specified rawColumnIdentifier. | 
| static java.nio.ByteBuffer[] | SelectStatement. getComponents(CFMetaData cfm,
             DecoratedKey dk) | 
| protected StatementRestrictions | ModificationStatement.Parsed. newRestrictions(CFMetaData cfm,
               VariableSpecifications boundNames,
               Operations operations,
               WhereClause where,
               Conditions conditions)Creates the restrictions. | 
| IndexTarget | IndexTarget.Raw. prepare(CFMetaData cfm) | 
| protected ModificationStatement | DeleteStatement.Parsed. prepareInternal(CFMetaData cfm,
               VariableSpecifications boundNames,
               Conditions conditions,
               Attributes attrs) | 
| protected abstract ModificationStatement | ModificationStatement.Parsed. prepareInternal(CFMetaData cfm,
               VariableSpecifications boundNames,
               Conditions conditions,
               Attributes attrs) | 
| protected ModificationStatement | UpdateStatement.ParsedInsert. prepareInternal(CFMetaData cfm,
               VariableSpecifications boundNames,
               Conditions conditions,
               Attributes attrs) | 
| protected ModificationStatement | UpdateStatement.ParsedInsertJson. prepareInternal(CFMetaData cfm,
               VariableSpecifications boundNames,
               Conditions conditions,
               Attributes attrs) | 
| protected ModificationStatement | UpdateStatement.ParsedUpdate. prepareInternal(CFMetaData cfm,
               VariableSpecifications boundNames,
               Conditions conditions,
               Attributes attrs) | 
| Constructor and Description | 
|---|
| CQL3CasRequest(CFMetaData cfm,
              DecoratedKey key,
              boolean isBatch,
              PartitionColumns conditionColumns,
              boolean updatesRegularRows,
              boolean updatesStaticRow) | 
| ModificationStatement(StatementType type,
                     int boundTerms,
                     CFMetaData cfm,
                     Operations operations,
                     StatementRestrictions restrictions,
                     Conditions conditions,
                     Attributes attrs) | 
| SelectStatement(CFMetaData cfm,
               int boundTerms,
               SelectStatement.Parameters parameters,
               Selection selection,
               StatementRestrictions restrictions,
               boolean isReversed,
               AggregationSpecification aggregationSpec,
               java.util.Comparator<java.util.List<java.nio.ByteBuffer>> orderingComparator,
               Term limit,
               Term perPartitionLimit) | 
| Modifier and Type | Field and Description | 
|---|---|
| static CFMetaData | SystemKeyspace. Batches | 
| static CFMetaData | SystemKeyspace. LegacyAggregatesDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyBatchlogDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyColumnfamiliesDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyColumnsDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyFunctionsDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyHintsDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyKeyspacesDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyTriggersDeprecated.  | 
| static CFMetaData | SystemKeyspace. LegacyUsertypesDeprecated.  | 
| CFMetaData | ColumnFamilyStore. metadata | 
| CFMetaData | LegacyLayout.CellGrouper. metadata | 
| protected CFMetaData | UnfilteredDeserializer. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | Memtable.MemtableUnfilteredPartitionIterator. metadata() | 
| CFMetaData | ReadCommand. metadata()The metadata for the table queried. | 
| CFMetaData | SimpleBuilders.PartitionUpdateBuilder. metadata() | 
| CFMetaData | SinglePartitionReadCommand.Group. metadata() | 
| CFMetaData | ReadExecutionController. metaData() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LegacyLayout.LegacyDeletionInfo. add(CFMetaData metadata,
   LegacyLayout.LegacyRangeTombstone tombstone) | 
| void | LegacyLayout.LegacyDeletionInfo. add(CFMetaData metadata,
   RangeTombstone tombstone) | 
| static PartitionRangeReadCommand | PartitionRangeReadCommand. allDataRead(CFMetaData metadata,
           int nowInSec)Creates a new read command that query all the data in the table. | 
| static LegacyLayout.LegacyCell | LegacyLayout.LegacyCell. counterUpdate(CFMetaData metadata,
             java.nio.ByteBuffer superColumnName,
             java.nio.ByteBuffer name,
             long value) | 
| static PartitionRangeReadCommand | PartitionRangeReadCommand. create(boolean isForThrift,
      CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DataRange dataRange) | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(boolean isForThrift,
      CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(boolean isForThrift,
      CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter,
      IndexMetadata indexMetadata)Creates a new read command on a single partition. | 
| static UnfilteredDeserializer | UnfilteredDeserializer. create(CFMetaData metadata,
      DataInputPlus in,
      SerializationHeader header,
      SerializationHelper helper,
      DeletionTime partitionDeletion,
      boolean readAllAsDynamic) | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      java.nio.ByteBuffer key,
      Slices slices)Creates a new single partition slice command for the provided slices. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Clustering name)Creates a new single partition name command for the provided row. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      ColumnFilter columnFilter,
      ClusteringIndexFilter filter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      java.util.NavigableSet<Clustering> names)Creates a new single partition name command for the provided rows. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Slice slice)Creates a new single partition slice command for the provided single slice. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Slices slices)Creates a new single partition slice command for the provided slices. | 
| static ColumnFamilyStore | ColumnFamilyStore. createColumnFamilyStore(Keyspace keyspace,
                       CFMetaData metadata,
                       boolean loadSSTables) | 
| static ColumnFamilyStore | ColumnFamilyStore. createColumnFamilyStore(Keyspace keyspace,
                       java.lang.String columnFamily,
                       CFMetaData metadata,
                       boolean loadSSTables) | 
| static ColumnFamilyStore | ColumnFamilyStore. createColumnFamilyStore(Keyspace keyspace,
                       java.lang.String columnFamily,
                       CFMetaData metadata,
                       Directories directories,
                       boolean loadSSTables,
                       boolean registerBookkeeping,
                       boolean offline)This is only directly used by offline tools | 
| static LegacyLayout.LegacyBound | LegacyLayout. decodeBound(CFMetaData metadata,
           java.nio.ByteBuffer bound,
           boolean isStart) | 
| static LegacyLayout.LegacyCellName | LegacyLayout. decodeCellName(CFMetaData metadata,
              java.nio.ByteBuffer cellname) | 
| static LegacyLayout.LegacyCellName | LegacyLayout. decodeCellName(CFMetaData metadata,
              java.nio.ByteBuffer cellname,
              boolean readAllAsDynamic) | 
| static LegacyLayout.LegacyCellName | LegacyLayout. decodeCellName(CFMetaData metadata,
              java.nio.ByteBuffer superColumnName,
              java.nio.ByteBuffer cellname) | 
| static Clustering | LegacyLayout. decodeClustering(CFMetaData metadata,
                java.nio.ByteBuffer value) | 
| static LegacyLayout.LegacyDeletionInfo | LegacyLayout.LegacyDeletionInfo. deserialize(CFMetaData metadata,
           DataInputPlus in) | 
| Columns | Columns.Serializer. deserialize(DataInputPlus in,
           CFMetaData metadata) | 
| abstract ReadCommand | ReadCommand.SelectionDeserializer. deserialize(DataInputPlus in,
           int version,
           boolean isDigest,
           int digestVersion,
           boolean isForThrift,
           CFMetaData metadata,
           int nowInSec,
           ColumnFilter columnFilter,
           RowFilter rowFilter,
           DataLimits limits,
           IndexMetadata index) | 
| DataRange | DataRange.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| Slices | Slices.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| static java.util.Iterator<LegacyLayout.LegacyCell> | LegacyLayout. deserializeCells(CFMetaData metadata,
                java.io.DataInput in,
                SerializationHelper.Flag flag,
                int size) | 
| SerializationHeader | SerializationHeader.Serializer. deserializeForMessaging(DataInputPlus in,
                       CFMetaData metadata,
                       ColumnFilter selection,
                       boolean hasStatic) | 
| void | LegacyLayout.LegacyUnfilteredPartition. digest(CFMetaData metadata,
      java.security.MessageDigest digest) | 
| static java.util.List<java.lang.String> | ColumnFamilyStoreCQLHelper. dumpReCreateStatements(CFMetaData metadata) | 
| java.nio.ByteBuffer | LegacyLayout.LegacyCellName. encode(CFMetaData metadata) | 
| static java.nio.ByteBuffer | LegacyLayout. encodeBound(CFMetaData metadata,
           ClusteringBound bound,
           boolean isStart) | 
| static java.nio.ByteBuffer | LegacyLayout. encodeCellName(CFMetaData metadata,
              ClusteringPrefix clustering,
              java.nio.ByteBuffer columnName,
              java.nio.ByteBuffer collectionElement) | 
| static java.nio.ByteBuffer | LegacyLayout. encodeClustering(CFMetaData metadata,
                ClusteringPrefix clustering) | 
| static LegacyLayout.LegacyCell | LegacyLayout.LegacyCell. expiring(CFMetaData metadata,
        java.nio.ByteBuffer superColumnName,
        java.nio.ByteBuffer name,
        java.nio.ByteBuffer value,
        long timestamp,
        int ttl,
        int nowInSec) | 
| static Row | LegacyLayout. extractStaticColumns(CFMetaData metadata,
                    DataInputPlus in,
                    Columns statics) | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. fullPartitionRead(CFMetaData metadata,
                 int nowInSec,
                 java.nio.ByteBuffer key)Creates a new read command that queries a single partition in its entirety. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. fullPartitionRead(CFMetaData metadata,
                 int nowInSec,
                 DecoratedKey key)Creates a new read command that queries a single partition in its entirety. | 
| PartitionUpdate | Mutation. get(CFMetaData cfm) | 
| Clustering | LegacyLayout.LegacyBound. getAsClustering(CFMetaData metadata) | 
| static java.lang.String | ColumnFamilyStoreCQLHelper. getCFMetadataAsCQL(CFMetaData metadata,
                  boolean includeDroppedColumns)Build a CQL String representation of Column Family Metadata | 
| static java.util.List<java.lang.String> | ColumnFamilyStoreCQLHelper. getDroppedColumnsAsCQL(CFMetaData metadata)Build a CQL String representation of Dropped Columns in the given Column Family. | 
| static java.util.List<java.lang.String> | ColumnFamilyStoreCQLHelper. getIndexesAsCQL(CFMetaData metadata)Build a CQL String representation of Indexes on columns in the given Column Family | 
| static java.util.List<java.lang.String> | ColumnFamilyStoreCQLHelper. getUserTypesAsCQL(CFMetaData metadata)Build a CQL String representation of User Types used in the given Column Family. | 
| static boolean | CompactTables. hasEmptyCompactValue(CFMetaData metadata) | 
| void | Keyspace. initCf(CFMetaData metadata,
      boolean loadSSTables)adds a cf to internal structures, ends up creating disk files). | 
| static boolean | ColumnFamilyStoreCQLHelper. isCqlCompatible(CFMetaData metaData)Whether or not the given metadata is compatible / representable with CQL Language | 
| boolean | LegacyLayout.LegacyRangeTombstone. isRowDeletion(CFMetaData metadata) | 
| static java.util.Comparator<LegacyLayout.LegacyCell> | LegacyLayout. legacyCellComparator(CFMetaData metadata) | 
| static java.util.Comparator<LegacyLayout.LegacyCell> | LegacyLayout. legacyCellComparator(CFMetaData metadata,
                    boolean reversed) | 
| static java.util.Comparator<LegacyLayout.LegacyCellName> | LegacyLayout. legacyCellNameComparator(CFMetaData metadata,
                        boolean reversed) | 
| static PaxosState | SystemKeyspace. loadPaxosState(DecoratedKey key,
              CFMetaData metadata,
              int nowInSec) | 
| static SerializationHeader | SerializationHeader. make(CFMetaData metadata,
    java.util.Collection<SSTableReader> sstables) | 
| static AbstractType<?> | LegacyLayout. makeLegacyComparator(CFMetaData metadata) | 
| static SerializationHeader | SerializationHeader. makeWithoutStats(CFMetaData metadata) | 
| static void | ExpirationDateOverflowHandling. maybeApplyExpirationDateOverflowPolicy(CFMetaData metadata,
                                      int ttl,
                                      boolean isDefaultTTL) | 
| static UnfilteredRowIterator | LegacyLayout. onWireCellstoUnfilteredRowIterator(CFMetaData metadata,
                                  DecoratedKey key,
                                  LegacyLayout.LegacyDeletionInfo delInfo,
                                  java.util.Iterator<LegacyLayout.LegacyCell> cells,
                                  boolean reversed,
                                  SerializationHelper helper) | 
| static ColumnFamilyStore | Keyspace. openAndGetStore(CFMetaData cfm) | 
| static int | SystemKeyspace. paxosTtlSec(CFMetaData metadata) | 
| static LegacyLayout.LegacyAtom | LegacyLayout. readLegacyAtom(CFMetaData metadata,
              DataInputPlus in,
              boolean readAllAsDynamic) | 
| static LegacyLayout.LegacyCell | LegacyLayout. readLegacyCell(CFMetaData metadata,
              java.io.DataInput in,
              SerializationHelper.Flag flag) | 
| static LegacyLayout.LegacyCell | LegacyLayout. readLegacyCellBody(CFMetaData metadata,
                  java.io.DataInput in,
                  java.nio.ByteBuffer cellname,
                  int mask,
                  SerializationHelper.Flag flag,
                  boolean readAllAsDynamic) | 
| static LegacyLayout.LegacyRangeTombstone | LegacyLayout. readLegacyRangeTombstoneBody(CFMetaData metadata,
                            DataInputPlus in,
                            java.nio.ByteBuffer boundname) | 
| static LegacyLayout.LegacyCell | LegacyLayout.LegacyCell. regular(CFMetaData metadata,
       java.nio.ByteBuffer superColumnName,
       java.nio.ByteBuffer name,
       java.nio.ByteBuffer value,
       long timestamp) | 
| static RowIterator | EmptyIterators. row(CFMetaData metadata,
   DecoratedKey partitionKey,
   boolean isReverseOrder) | 
| static void | ColumnFamilyStore. scrubDataDirectories(CFMetaData metadata)Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
 and compacted sstables. | 
| void | LegacyLayout.LegacyRangeTombstoneList. serialize(DataOutputPlus out,
         CFMetaData metadata) | 
| void | DataRange.Serializer. serialize(DataRange range,
         DataOutputPlus out,
         int version,
         CFMetaData metadata) | 
| long | LegacyLayout.LegacyRangeTombstoneList. serializedSize(CFMetaData metadata) | 
| long | DataRange.Serializer. serializedSize(DataRange range,
              int version,
              CFMetaData metadata) | 
| static LegacyLayout.CellGrouper | LegacyLayout.CellGrouper. staticGrouper(CFMetaData metadata,
             SerializationHelper helper) | 
| default java.lang.String | Clustering. toCQLString(CFMetaData metadata) | 
| java.lang.String | DataRange. toCQLString(CFMetaData metadata) | 
| abstract java.lang.String | Slices. toCQLString(CFMetaData metadata) | 
| SerializationHeader | SerializationHeader.Component. toHeader(CFMetaData metadata) | 
| static LegacyLayout.LegacyCell | LegacyLayout.LegacyCell. tombstone(CFMetaData metadata,
         java.nio.ByteBuffer superColumnName,
         java.nio.ByteBuffer name,
         long timestamp,
         int nowInSec) | 
| static RowIterator | LegacyLayout. toRowIterator(CFMetaData metadata,
             DecoratedKey key,
             java.util.Iterator<LegacyLayout.LegacyCell> cells,
             int nowInSec) | 
| default java.lang.String | Clustering. toString(CFMetaData metadata) | 
| java.lang.String | ClusteringBoundOrBoundary. toString(CFMetaData metadata) | 
| java.lang.String | ClusteringPrefix. toString(CFMetaData metadata)Generates a proper string representation of the prefix. | 
| java.lang.String | DataRange. toString(CFMetaData metadata) | 
| java.lang.String | DataRange.Paging. toString(CFMetaData metadata) | 
| java.lang.String | Slice. toString(CFMetaData metadata) | 
| static UnfilteredRowIterator | LegacyLayout. toUnfilteredRowIterator(CFMetaData metadata,
                       DecoratedKey key,
                       LegacyLayout.LegacyDeletionInfo delInfo,
                       java.util.Iterator<LegacyLayout.LegacyCell> cells) | 
| static UnfilteredPartitionIterator | EmptyIterators. unfilteredPartition(CFMetaData metadata,
                   boolean isForThrift) | 
| static UnfilteredRowIterator | EmptyIterators. unfilteredRow(CFMetaData metadata,
             DecoratedKey partitionKey,
             boolean isReverseOrder) | 
| static UnfilteredRowIterator | EmptyIterators. unfilteredRow(CFMetaData metadata,
             DecoratedKey partitionKey,
             boolean isReverseOrder,
             Row staticRow,
             DeletionTime partitionDeletion) | 
| PartitionUpdate.SimpleBuilder | Mutation.SimpleBuilder. update(CFMetaData metadata)Adds an update for table identified by the provided metadata and return a builder for that partition. | 
| PartitionUpdate.SimpleBuilder | SimpleBuilders.MutationBuilder. update(CFMetaData metadata) | 
| void | ConsistencyLevel. validateCounterForWrite(CFMetaData metadata) | 
| Constructor and Description | 
|---|
| CellGrouper(CFMetaData metadata,
           SerializationHelper helper) | 
| ColumnFamilyStore(Keyspace keyspace,
                 java.lang.String columnFamilyName,
                 int generation,
                 CFMetaData metadata,
                 Directories directories,
                 boolean loadSSTables,
                 boolean registerBookeeping,
                 boolean offline) | 
| Directories(CFMetaData metadata) | 
| Directories(CFMetaData metadata,
           java.util.Collection<Directories.DataDirectory> paths) | 
| Directories(CFMetaData metadata,
           Directories.DataDirectory[] paths)Create Directories of given ColumnFamily. | 
| Memtable(CFMetaData metadata) | 
| PartitionUpdateBuilder(CFMetaData metadata,
                      java.lang.Object... partitionKeyValues) | 
| ReadCommand(ReadCommand.Kind kind,
           boolean isDigestQuery,
           int digestVersion,
           boolean isForThrift,
           CFMetaData metadata,
           int nowInSec,
           ColumnFilter columnFilter,
           RowFilter rowFilter,
           DataLimits limits,
           IndexMetadata index) | 
| RowBuilder(CFMetaData metadata,
          java.lang.Object... clusteringColumns) | 
| SerializationHeader(boolean isForSSTable,
                   CFMetaData metadata,
                   PartitionColumns columns,
                   EncodingStats stats) | 
| Serializer(CFMetaData metadata,
          Version version,
          SerializationHeader header) | 
| Serializers(CFMetaData metadata) | 
| UnfilteredDeserializer(CFMetaData metadata,
                      DataInputPlus in,
                      SerializationHelper helper) | 
| UnknownColumnException(CFMetaData metadata,
                      java.nio.ByteBuffer columnName) | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | AbstractSSTableIterator. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | CompactionInfo. getCFMetaData() | 
| CFMetaData | CompactionIterator. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CompactionStrategyManager. maybeReload(CFMetaData metadata) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CompactionManager. interruptCompactionFor(java.lang.Iterable<CFMetaData> columnFamilies,
                      boolean interruptValidation)Try to stop all of the compactions for given ColumnFamilies. | 
| Constructor and Description | 
|---|
| CompactionInfo(CFMetaData cfm,
              OperationType tasktype,
              long completed,
              long total,
              java.lang.String unit,
              java.util.UUID compactionId) | 
| CompactionInfo(CFMetaData cfm,
              OperationType tasktype,
              long bytesComplete,
              long totalBytes,
              java.util.UUID compactionId) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RowFilter. addCustomIndexExpression(CFMetaData cfm,
                        IndexMetadata targetIndex,
                        java.nio.ByteBuffer value) | 
| void | RowFilter. addThriftExpression(CFMetaData metadata,
                   java.nio.ByteBuffer name,
                   Operator op,
                   java.nio.ByteBuffer value) | 
| static ColumnFilter | ColumnFilter. all(CFMetaData metadata)A filter that includes all columns for the provided table. | 
| static ColumnFilter.Builder | ColumnFilter. allColumnsBuilder(CFMetaData metadata)Returns a  ColumnFilter} builder that fetches all columns (and queries the columns
 added to the builder, or everything if no column is added). | 
| protected void | AbstractClusteringIndexFilter. appendOrderByToCQLString(CFMetaData metadata,
                        java.lang.StringBuilder sb) | 
| ClusteringIndexFilter | ClusteringIndexFilter.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| ColumnFilter | ColumnFilter.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| ColumnSubselection | ColumnSubselection.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| protected abstract RowFilter.UserExpression | RowFilter.UserExpression.Deserializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| RowFilter | RowFilter.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata) | 
| ClusteringIndexFilter | ClusteringIndexFilter.InternalDeserializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata,
           boolean reversed) | 
| Slices | ClusteringIndexFilter. getSlices(CFMetaData metadata) | 
| Slices | ClusteringIndexNamesFilter. getSlices(CFMetaData metadata) | 
| Slices | ClusteringIndexSliceFilter. getSlices(CFMetaData metadata) | 
| protected java.nio.ByteBuffer | RowFilter.Expression. getValue(CFMetaData metadata,
        DecoratedKey partitionKey,
        Row row) | 
| abstract boolean | RowFilter.Expression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row)Returns whether the provided row satisfied this expression or not. | 
| boolean | RowFilter.SimpleExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter.CustomExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row,
             int nowInSec)Whether the provided row in the provided partition satisfies this filter. | 
| static ColumnFilter | ColumnFilter. selection(CFMetaData metadata,
         PartitionColumns queried)A filter that fetches all columns for the provided table, but returns
 only the queried ones. | 
| java.lang.String | ClusteringIndexFilter. toCQLString(CFMetaData metadata) | 
| java.lang.String | ClusteringIndexNamesFilter. toCQLString(CFMetaData metadata) | 
| java.lang.String | ClusteringIndexSliceFilter. toCQLString(CFMetaData metadata) | 
| java.lang.String | ClusteringIndexFilter. toString(CFMetaData metadata) | 
| java.lang.String | ClusteringIndexNamesFilter. toString(CFMetaData metadata) | 
| java.lang.String | ClusteringIndexSliceFilter. toString(CFMetaData metadata) | 
| Constructor and Description | 
|---|
| CustomExpression(CFMetaData cfm,
                IndexMetadata targetIndex,
                java.nio.ByteBuffer value) | 
| TombstoneOverwhelmingException(int numTombstones,
                              java.lang.String query,
                              CFMetaData metadata,
                              DecoratedKey lastPartitionKey,
                              ClusteringPrefix lastClustering) | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | LifecycleTransaction. removeUnfinishedLeftovers(CFMetaData cfMetaData) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected CFMetaData | AbstractBTreePartition. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | AbstractBTreePartition. metadata() | 
| CFMetaData | Partition. metadata() | 
| CFMetaData | PartitionUpdate.SimpleBuilder. metadata()The metadata of the table this is a builder on. | 
| CFMetaData | SingletonUnfilteredPartitionIterator. metadata() | 
| CFMetaData | UnfilteredPartitionIterator. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| UnfilteredPartitionIterator | UnfilteredPartitionIterators.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata,
           ColumnFilter selection,
           SerializationHelper.Flag flag) | 
| static PartitionUpdate | PartitionUpdate. emptyUpdate(CFMetaData metadata,
           DecoratedKey key)Creates a empty immutable partition update. | 
| static PartitionUpdate | PartitionUpdate. fullPartitionDelete(CFMetaData metadata,
                   java.nio.ByteBuffer key,
                   long timestamp,
                   int nowInSec)Creates a partition update that entirely deletes a given partition. | 
| static PartitionUpdate | PartitionUpdate. fullPartitionDelete(CFMetaData metadata,
                   DecoratedKey key,
                   long timestamp,
                   int nowInSec)Creates an immutable partition update that entirely deletes a given partition. | 
| static PartitionUpdate.SimpleBuilder | PartitionUpdate. simpleBuilder(CFMetaData metadata,
             java.lang.Object... partitionKeyValues)Creates a new simple partition update builder. | 
| static PartitionUpdate | PartitionUpdate. singleRowUpdate(CFMetaData metadata,
               java.nio.ByteBuffer key,
               Row row)Creates an immutable partition update that contains a single row update. | 
| static PartitionUpdate | PartitionUpdate. singleRowUpdate(CFMetaData metadata,
               DecoratedKey key,
               Row row)Creates an immutable partition update that contains a single row update. | 
| Constructor and Description | 
|---|
| AbstractBTreePartition(CFMetaData metadata,
                      DecoratedKey partitionKey) | 
| AtomicBTreePartition(CFMetaData metadata,
                    DecoratedKey partitionKey,
                    MemtableAllocator allocator) | 
| ImmutableBTreePartition(CFMetaData metadata,
                       DecoratedKey partitionKey,
                       AbstractBTreePartition.Holder holder) | 
| ImmutableBTreePartition(CFMetaData metadata,
                       DecoratedKey partitionKey,
                       PartitionColumns columns,
                       Row staticRow,
                       java.lang.Object[] tree,
                       DeletionInfo deletionInfo,
                       EncodingStats stats) | 
| PartitionUpdate(CFMetaData metadata,
               java.nio.ByteBuffer key,
               PartitionColumns columns,
               int initialRowCapacity) | 
| PartitionUpdate(CFMetaData metadata,
               DecoratedKey key,
               PartitionColumns columns,
               int initialRowCapacity) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected CFMetaData | AbstractUnfilteredRowIterator. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | AbstractUnfilteredRowIterator. metadata() | 
| CFMetaData | BaseRowIterator. metadata()The metadata for the table this iterator on. | 
| CFMetaData | LazilyInitializedUnfilteredRowIterator. metadata() | 
| CFMetaData | UnfilteredRowIteratorWithLowerBound. metadata() | 
| CFMetaData | WrappingUnfilteredRowIterator. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| java.lang.Iterable<Cell> | BTreeRow. cellsInLegacyOrder(CFMetaData metadata,
                  boolean reversed) | 
| java.lang.Iterable<Cell> | Row. cellsInLegacyOrder(CFMetaData metadata,
                  boolean reversed)An iterable over the cells of this row that return cells in "legacy order". | 
| UnfilteredRowIterator | UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata,
           ColumnFilter selection,
           SerializationHelper.Flag flag) | 
| UnfilteredRowIterator | UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData metadata,
           SerializationHelper.Flag flag,
           UnfilteredRowIteratorSerializer.Header header) | 
| UnfilteredRowIteratorSerializer.Header | UnfilteredRowIteratorSerializer. deserializeHeader(CFMetaData metadata,
                 ColumnFilter selection,
                 DataInputPlus in,
                 int version,
                 SerializationHelper.Flag flag) | 
| Row | BTreeRow. filter(ColumnFilter filter,
      CFMetaData metadata) | 
| Row | Row. filter(ColumnFilter filter,
      CFMetaData metadata)Returns a copy of this row that:
   1) only includes the data for the column included by  filter. | 
| Row | BTreeRow. filter(ColumnFilter filter,
      DeletionTime activeDeletion,
      boolean setActiveDeletionToRow,
      CFMetaData metadata) | 
| Row | Row. filter(ColumnFilter filter,
      DeletionTime activeDeletion,
      boolean setActiveDeletionToRow,
      CFMetaData metadata)Returns a copy of this row that:
   1) only includes the data for the column included by  filter. | 
| static UnfilteredRowIterator | UnfilteredRowIterators. noRowsIterator(CFMetaData cfm,
              DecoratedKey partitionKey,
              Row staticRow,
              DeletionTime partitionDeletion,
              boolean isReverseOrder)Returns an empty unfiltered iterator for a given partition. | 
| static Row.SimpleBuilder | Rows. simpleBuilder(CFMetaData metadata,
             java.lang.Object... clusteringValues)Creates a new simple row builder. | 
| java.lang.String | AbstractRow. toString(CFMetaData metadata) | 
| java.lang.String | RangeTombstoneBoundMarker. toString(CFMetaData metadata) | 
| java.lang.String | RangeTombstoneBoundaryMarker. toString(CFMetaData metadata) | 
| java.lang.String | Unfiltered. toString(CFMetaData metadata) | 
| java.lang.String | AbstractRangeTombstoneMarker. toString(CFMetaData metadata,
        boolean fullDetails) | 
| java.lang.String | AbstractRow. toString(CFMetaData metadata,
        boolean fullDetails) | 
| java.lang.String | Row. toString(CFMetaData metadata,
        boolean fullDetails) | 
| java.lang.String | Unfiltered. toString(CFMetaData metadata,
        boolean fullDetails) | 
| java.lang.String | AbstractRangeTombstoneMarker. toString(CFMetaData metadata,
        boolean includeClusteringKeys,
        boolean fullDetails) | 
| java.lang.String | AbstractRow. toString(CFMetaData metadata,
        boolean includeClusterKeys,
        boolean fullDetails) | 
| java.lang.String | Unfiltered. toString(CFMetaData metadata,
        boolean includeClusterKeys,
        boolean fullDetails) | 
| void | AbstractRangeTombstoneMarker. validateData(CFMetaData metadata) | 
| void | AbstractRow. validateData(CFMetaData metadata) | 
| void | Unfiltered. validateData(CFMetaData metadata)Validate the data of this atom. | 
| Constructor and Description | 
|---|
| AbstractUnfilteredRowIterator(CFMetaData metadata,
                             DecoratedKey partitionKey,
                             DeletionTime partitionLevelDeletion,
                             PartitionColumns columns,
                             Row staticRow,
                             boolean isReverseOrder,
                             EncodingStats stats) | 
| RowAndDeletionMergeIterator(CFMetaData metadata,
                           DecoratedKey partitionKey,
                           DeletionTime partitionLevelDeletion,
                           ColumnFilter selection,
                           Row staticRow,
                           boolean isReversed,
                           EncodingStats stats,
                           java.util.Iterator<Row> rows,
                           java.util.Iterator<RangeTombstone> ranges,
                           boolean removeShadowedData) | 
| SerializationHelper(CFMetaData metadata,
                   int version,
                   SerializationHelper.Flag flag) | 
| SerializationHelper(CFMetaData metadata,
                   int version,
                   SerializationHelper.Flag flag,
                   ColumnFilter columnsToFetch) | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | BaseRows. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| static CFMetaData | View. findBaseTable(java.lang.String keyspace,
             java.lang.String viewName) | 
| Modifier and Type | Method and Description | 
|---|---|
| TableViews | ViewManager. forTable(CFMetaData metadata) | 
| Constructor and Description | 
|---|
| TableViews(CFMetaData baseTableMetadata) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Pair<ColumnDefinition,IndexTarget.Type> | TargetParser. parse(CFMetaData cfm,
     IndexMetadata indexDef) | 
| static Pair<ColumnDefinition,IndexTarget.Type> | TargetParser. parse(CFMetaData cfm,
     java.lang.String target) | 
| Modifier and Type | Method and Description | 
|---|---|
| static CFMetaData | CassandraIndex. indexCfsMetadata(CFMetaData baseCfsMetadata,
                IndexMetadata indexMetadata)Construct the CFMetadata for an index table, the clustering columns in the index table
 vary dependent on the kind of the indexed value. | 
| Modifier and Type | Method and Description | 
|---|---|
| default CFMetaData.Builder | CassandraIndexFunctions. addIndexClusteringColumns(CFMetaData.Builder builder,
                         CFMetaData baseMetadata,
                         ColumnDefinition cfDef)Add the clustering columns for a specific type of index table to the a CFMetaData.Builder (which is being
 used to construct the index table's CFMetadata. | 
| static CFMetaData | CassandraIndex. indexCfsMetadata(CFMetaData baseCfsMetadata,
                IndexMetadata indexMetadata)Construct the CFMetadata for an index table, the clustering columns in the index table
 vary dependent on the kind of the indexed value. | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData.Builder | KeysIndex. addIndexClusteringColumns(CFMetaData.Builder builder,
                         CFMetaData baseMetadata,
                         ColumnDefinition cfDef) | 
| Modifier and Type | Method and Description | 
|---|---|
| static java.util.Map<java.lang.String,java.lang.String> | SASIIndex. validateOptions(java.util.Map<java.lang.String,java.lang.String> options,
               CFMetaData cfm) | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | QueryController. metadata() | 
| Modifier and Type | Field and Description | 
|---|---|
| CFMetaData | SSTable. metadata | 
| protected CFMetaData | SSTableSimpleIterator. metadata | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract CFMetaData | SSTableLoader.Client. getTableMetadata(java.lang.String tableName)Validate that  keyspaceis an existing keyspace andcfNameone of its existing column family. | 
| CFMetaData | SSTableIdentityIterator. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| static SSTableSimpleIterator | SSTableSimpleIterator. create(CFMetaData metadata,
      DataInputPlus in,
      SerializationHeader header,
      SerializationHelper helper,
      DeletionTime partitionDeletion) | 
| static SSTableTxnWriter | SSTableTxnWriter. create(CFMetaData cfm,
      Descriptor descriptor,
      long keyCount,
      long repairedAt,
      int sstableLevel,
      SerializationHeader header,
      java.util.Collection<Index> indexes) | 
| static SSTableMultiWriter | SimpleSSTableMultiWriter. create(Descriptor descriptor,
      long keyCount,
      long repairedAt,
      CFMetaData cfm,
      MetadataCollector metadataCollector,
      SerializationHeader header,
      java.util.Collection<Index> indexes,
      LifecycleTransaction txn) | 
| static SSTableTxnWriter | SSTableTxnWriter. createRangeAware(CFMetaData cfm,
                long keyCount,
                long repairedAt,
                SSTableFormat.Type type,
                int sstableLevel,
                SerializationHeader header) | 
| static SSTableSimpleIterator | SSTableSimpleIterator. createTombstoneOnly(CFMetaData metadata,
                   DataInputPlus in,
                   SerializationHeader header,
                   SerializationHelper helper,
                   DeletionTime partitionDeletion) | 
| void | SSTableLoader.Client. setTableMetadata(CFMetaData cfm) | 
| Constructor and Description | 
|---|
| KeyIterator(Descriptor desc,
           CFMetaData metadata) | 
| SSTable(Descriptor descriptor,
       java.util.Set<Component> components,
       CFMetaData metadata,
       DiskOptimizationStrategy optimizationStrategy) | 
| Modifier and Type | Method and Description | 
|---|---|
| static SSTableWriter | SSTableWriter. create(CFMetaData metadata,
      Descriptor descriptor,
      long keyCount,
      long repairedAt,
      int sstableLevel,
      SerializationHeader header,
      java.util.Collection<Index> indexes,
      LifecycleTransaction txn) | 
| static SSTableWriter | SSTableWriter. create(Descriptor descriptor,
      java.lang.Long keyCount,
      java.lang.Long repairedAt,
      CFMetaData metadata,
      MetadataCollector metadataCollector,
      SerializationHeader header,
      java.util.Collection<Index> indexes,
      LifecycleTransaction txn) | 
| RowIndexEntry.IndexSerializer<?> | SSTableFormat. getIndexSerializer(CFMetaData cfm,
                  Version version,
                  SerializationHeader header) | 
| static SSTableReader | SSTableReader. internalOpen(Descriptor desc,
            java.util.Set<Component> components,
            CFMetaData metadata,
            FileHandle ifile,
            FileHandle dfile,
            IndexSummary isummary,
            IFilter bf,
            long maxDataAge,
            StatsMetadata sstableMetadata,
            SSTableReader.OpenReason openReason,
            SerializationHeader header)Open a RowIndexedReader which already has its state initialized (by SSTableWriter). | 
| static SSTableReader | SSTableReader. open(Descriptor desc,
    CFMetaData metadata) | 
| abstract SSTableWriter | SSTableWriter.Factory. open(Descriptor descriptor,
    long keyCount,
    long repairedAt,
    CFMetaData metadata,
    MetadataCollector metadataCollector,
    SerializationHeader header,
    java.util.Collection<SSTableFlushObserver> observers,
    LifecycleTransaction txn) | 
| static SSTableReader | SSTableReader. open(Descriptor descriptor,
    java.util.Set<Component> components,
    CFMetaData metadata) | 
| static SSTableReader | SSTableReader. open(Descriptor descriptor,
    java.util.Set<Component> components,
    CFMetaData metadata,
    boolean validate,
    boolean trackHotness) | 
| abstract SSTableReader | SSTableReader.Factory. open(Descriptor descriptor,
    java.util.Set<Component> components,
    CFMetaData metadata,
    java.lang.Long maxDataAge,
    StatsMetadata sstableMetadata,
    SSTableReader.OpenReason openReason,
    SerializationHeader header) | 
| static java.util.Collection<SSTableReader> | SSTableReader. openAll(java.util.Set<java.util.Map.Entry<Descriptor,java.util.Set<Component>>> entries,
       CFMetaData metadata) | 
| static SSTableReader | SSTableReader. openForBatch(Descriptor descriptor,
            java.util.Set<Component> components,
            CFMetaData metadata)Open SSTable reader to be used in batch mode(such as sstableloader). | 
| static SSTableReader | SSTableReader. openNoValidation(Descriptor descriptor,
                CFMetaData metadata) | 
| Constructor and Description | 
|---|
| SSTableReader(Descriptor desc,
             java.util.Set<Component> components,
             CFMetaData metadata,
             long maxDataAge,
             StatsMetadata sstableMetadata,
             SSTableReader.OpenReason openReason,
             SerializationHeader header) | 
| SSTableWriter(Descriptor descriptor,
             long keyCount,
             long repairedAt,
             CFMetaData metadata,
             MetadataCollector metadataCollector,
             SerializationHeader header,
             java.util.Collection<SSTableFlushObserver> observers) | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | BigTableScanner. metadata() | 
| CFMetaData | BigTableScanner.EmptySSTableScanner. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| RowIndexEntry.IndexSerializer | BigFormat. getIndexSerializer(CFMetaData metadata,
                  Version version,
                  SerializationHeader header) | 
| Constructor and Description | 
|---|
| BigTableWriter(Descriptor descriptor,
              long keyCount,
              long repairedAt,
              CFMetaData metadata,
              MetadataCollector metadataCollector,
              SerializationHeader header,
              java.util.Collection<SSTableFlushObserver> observers,
              LifecycleTransaction txn) | 
| Modifier and Type | Field and Description | 
|---|---|
| static java.util.List<CFMetaData> | SchemaKeyspace. ALL_TABLE_METADATA | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | Tables. getNullable(java.lang.String name)Get the table with the specified name | 
| CFMetaData | KeyspaceMetadata. getTableOrViewNullable(java.lang.String tableOrViewName) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.Optional<CFMetaData> | KeyspaceMetadata. findIndexedTable(java.lang.String indexName) | 
| java.util.Optional<CFMetaData> | Tables. get(java.lang.String name)Get the table with the specified name | 
| java.util.Iterator<CFMetaData> | Tables. iterator() | 
| java.lang.Iterable<CFMetaData> | Views. metadatas() | 
| java.lang.Iterable<CFMetaData> | KeyspaceMetadata. tablesAndViews() | 
| Modifier and Type | Method and Description | 
|---|---|
| Tables.Builder | Tables.Builder. add(CFMetaData... tables) | 
| Tables.Builder | Tables.Builder. add(CFMetaData table) | 
| IndexMetadata | IndexMetadata.Serializer. deserialize(DataInputPlus in,
           int version,
           CFMetaData cfm) | 
| static IndexMetadata | IndexMetadata. fromIndexTargets(CFMetaData cfm,
                java.util.List<IndexTarget> targets,
                java.lang.String name,
                IndexMetadata.Kind kind,
                java.util.Map<java.lang.String,java.lang.String> options) | 
| static IndexMetadata | IndexMetadata. fromLegacyMetadata(CFMetaData cfm,
                  ColumnDefinition column,
                  java.lang.String name,
                  IndexMetadata.Kind kind,
                  java.util.Map<java.lang.String,java.lang.String> options) | 
| static Mutation.SimpleBuilder | SchemaKeyspace. makeCreateTableMutation(KeyspaceMetadata keyspace,
                       CFMetaData table,
                       long timestamp) | 
| static Mutation.SimpleBuilder | SchemaKeyspace. makeDropTableMutation(KeyspaceMetadata keyspace,
                     CFMetaData table,
                     long timestamp) | 
| static Mutation.SimpleBuilder | SchemaKeyspace. makeUpdateTableMutation(KeyspaceMetadata keyspace,
                       CFMetaData oldTable,
                       CFMetaData newTable,
                       long timestamp) | 
| static Tables | Tables. of(CFMetaData... tables) | 
| Views | Views. replace(ViewDefinition view,
       CFMetaData cfm)Creates a MaterializedViews instance which contains an updated materialized view | 
| void | IndexMetadata. validate(CFMetaData cfm) | 
| Tables | Tables. with(CFMetaData table)Create a Tables instance with the provided table added | 
| Modifier and Type | Method and Description | 
|---|---|
| Tables.Builder | Tables.Builder. add(java.lang.Iterable<CFMetaData> tables) | 
| static Tables | Tables. of(java.lang.Iterable<CFMetaData> tables) | 
| Constructor and Description | 
|---|
| UnknownIndexException(CFMetaData metadata,
                     java.util.UUID id) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | MigrationManager. announceColumnFamilyUpdate(CFMetaData cfm) | 
| static void | MigrationManager. announceColumnFamilyUpdate(CFMetaData cfm,
                          boolean announceLocally) | 
| static void | MigrationManager. announceColumnFamilyUpdate(CFMetaData cfm,
                          java.util.Collection<ViewDefinition> views,
                          boolean announceLocally) | 
| static void | MigrationManager. announceNewColumnFamily(CFMetaData cfm) | 
| static void | MigrationManager. announceNewColumnFamily(CFMetaData cfm,
                       boolean announceLocally) | 
| static void | MigrationManager. forceAnnounceNewColumnFamily(CFMetaData cfm)Announces the table even if the definition is already know locally. | 
| void | ClientState. hasColumnFamilyAccess(CFMetaData cfm,
                     Permission perm) | 
| void | MigrationManager. notifyCreateColumnFamily(CFMetaData cfm) | 
| void | MigrationManager. notifyDropColumnFamily(CFMetaData cfm) | 
| void | MigrationManager. notifyUpdateColumnFamily(CFMetaData cfm,
                        boolean columnsDidChange) | 
| Modifier and Type | Method and Description | 
|---|---|
| Clustering | PagingState.RowMark. clustering(CFMetaData metadata) | 
| static int | QueryPagers. countPaged(CFMetaData metadata,
          DecoratedKey key,
          ColumnFilter columnFilter,
          ClusteringIndexFilter filter,
          DataLimits limits,
          ConsistencyLevel consistencyLevel,
          ClientState state,
          int pageSize,
          int nowInSec,
          boolean isForThrift,
          long queryStartNanoTime)Convenience method that count (live) cells/rows for a given slice of a row, but page underneath. | 
| static PagingState.RowMark | PagingState.RowMark. create(CFMetaData metadata,
      Row row,
      ProtocolVersion protocolVersion) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Commit | Commit. emptyCommit(DecoratedKey key,
           CFMetaData metadata) | 
| static Commit | Commit. newPrepare(DecoratedKey key,
          CFMetaData metadata,
          java.util.UUID ballot) | 
| java.lang.Iterable<java.net.InetAddress> | PrepareCallback. replicasMissingMostRecentCommit(CFMetaData metadata,
                               int nowInSec) | 
| Constructor and Description | 
|---|
| PaxosState(DecoratedKey key,
          CFMetaData metadata) | 
| PrepareCallback(DecoratedKey key,
               CFMetaData metadata,
               int targets,
               ConsistencyLevel consistency,
               long queryStartNanoTime) | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | StreamReader.StreamDeserializer. metadata() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected SerializationHeader | StreamReader. getHeader(CFMetaData metadata) | 
| Constructor and Description | 
|---|
| StreamDeserializer(CFMetaData metadata,
                  java.io.InputStream in,
                  Version version,
                  SerializationHeader header,
                  long totalSize,
                  java.util.UUID sessionId) | 
| Modifier and Type | Method and Description | 
|---|---|
| static CFMetaData | ThriftConversion. fromThrift(CfDef cf_def) | 
| static CFMetaData | ThriftConversion. fromThriftForUpdate(CfDef cf_def,
                   CFMetaData toUpdate) | 
| 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| static KeyspaceMetadata | ThriftConversion. fromThrift(KsDef ksd,
          CFMetaData... cfDefs) | 
| static CFMetaData | ThriftConversion. fromThriftForUpdate(CfDef cf_def,
                   CFMetaData toUpdate) | 
| static UnfilteredPartitionIterator | ThriftResultsMerger. maybeWrap(UnfilteredPartitionIterator iterator,
         CFMetaData metadata,
         int nowInSec) | 
| static RowFilter | ThriftConversion. rowFilterFromThrift(CFMetaData metadata,
                   java.util.List<IndexExpression> exprs) | 
| java.util.List<ColumnOrSuperColumn> | CassandraServer. thriftifyColumns(CFMetaData metadata,
                java.util.Iterator<LegacyLayout.LegacyCell> cells) | 
| static CfDef | ThriftConversion. toThrift(CFMetaData cfm) | 
| static ColumnDef | ThriftConversion. toThrift(CFMetaData cfMetaData,
        ColumnDefinition column) | 
| 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 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. 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 | 
|---|---|
| static CFMetaData | SSTableExport. metadataFromSSTable(Descriptor desc)Construct table schema from info stored in SSTable's Stats.db | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | JsonTransformer. keysToJson(ISSTableScanner currentScanner,
          java.util.stream.Stream<DecoratedKey> keys,
          boolean rawTime,
          CFMetaData metadata,
          java.io.OutputStream out) | 
| static void | JsonTransformer. toJson(ISSTableScanner currentScanner,
      java.util.stream.Stream<UnfilteredRowIterator> partitions,
      boolean rawTime,
      CFMetaData metadata,
      java.io.OutputStream out) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected java.util.Map<java.lang.String,CFMetaData> | NativeSSTableLoaderClient. tables | 
| Modifier and Type | Method and Description | 
|---|---|
| CFMetaData | NativeSSTableLoaderClient. getTableMetadata(java.lang.String tableName) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NativeSSTableLoaderClient. setTableMetadata(CFMetaData cfm) | 
Copyright © 2018 The Apache Software Foundation