Uses of Class
org.apache.cassandra.schema.TableMetadata
-
-
Uses of TableMetadata in org.apache.cassandra.auth
Methods in org.apache.cassandra.auth with parameters of type TableMetadata Modifier and Type Method Description void
AuthSchemaChangeListener. onDropTable(TableMetadata table, boolean dropData)
-
Uses of TableMetadata in org.apache.cassandra.cache
Methods in org.apache.cassandra.cache with parameters of type TableMetadata Modifier and Type Method Description static CounterCacheKey
CounterCacheKey. create(TableMetadata tableMetadata, java.nio.ByteBuffer partitionKey, Clustering<?> clustering, ColumnMetadata c, CellPath path)
static CounterCacheKey
CounterCacheKey. read(TableMetadata tableMetadata, DataInputPlus in)
boolean
CacheKey. sameTable(TableMetadata tableMetadata)
Constructors in org.apache.cassandra.cache with parameters of type TableMetadata Constructor Description CacheKey(TableMetadata metadata)
KeyCacheKey(TableMetadata tableMetadata, Descriptor desc, java.nio.ByteBuffer key)
RowCacheKey(TableMetadata metadata, DecoratedKey key)
-
Uses of TableMetadata in org.apache.cassandra.cql3
Fields in org.apache.cassandra.cql3 declared as TableMetadata Modifier and Type Field Description TableMetadata
UpdateParameters. metadata
Methods in org.apache.cassandra.cql3 with parameters of type TableMetadata Modifier and Type Method Description Ordering.Expression
Ordering.Raw.Ann. bind(TableMetadata table, VariableSpecifications boundNames)
Ordering
Ordering.Raw. bind(TableMetadata table, VariableSpecifications boundNames)
Resolves column identifiers against the table schema.Ordering.Expression
Ordering.Raw.Expression. bind(TableMetadata table, VariableSpecifications boundNames)
Ordering.Expression
Ordering.Raw.SingleColumn. bind(TableMetadata table, VariableSpecifications boundNames)
static UntypedResultSet.Row
UntypedResultSet.Row. fromInternalRow(TableMetadata metadata, DecoratedKey key, Row row)
short[]
VariableSpecifications. getPartitionKeyBindVariableIndexes(TableMetadata metadata)
Returns an array with the same length as the number of partition key columns for the table corresponding to table.int
Attributes. getTimeToLive(QueryOptions options, TableMetadata metadata)
protected Restriction
MultiColumnRelation. newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey)
protected abstract Restriction
Relation. newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey)
Creates a new Contains restriction instance.protected Restriction
SingleColumnRelation. newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey)
protected Restriction
TokenRelation. newContainsRestriction(TableMetadata table, VariableSpecifications boundNames, boolean isKey)
protected Restriction
MultiColumnRelation. newEQRestriction(TableMetadata table, VariableSpecifications boundNames)
protected abstract Restriction
Relation. newEQRestriction(TableMetadata table, VariableSpecifications boundNames)
Creates a new EQ restriction instance.protected Restriction
SingleColumnRelation. newEQRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
TokenRelation. newEQRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
MultiColumnRelation. newINRestriction(TableMetadata table, VariableSpecifications boundNames)
protected abstract Restriction
Relation. newINRestriction(TableMetadata table, VariableSpecifications boundNames)
Creates a new IN restriction instance.protected Restriction
SingleColumnRelation. newINRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
TokenRelation. newINRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
MultiColumnRelation. newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames)
protected abstract Restriction
Relation. newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
SingleColumnRelation. newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
TokenRelation. newIsNotRestriction(TableMetadata table, VariableSpecifications boundNames)
protected Restriction
MultiColumnRelation. newLikeRestriction(TableMetadata table, VariableSpecifications boundNames, Operator operator)
protected abstract Restriction
Relation. newLikeRestriction(TableMetadata table, VariableSpecifications boundNames, Operator operator)
protected Restriction
SingleColumnRelation. newLikeRestriction(TableMetadata table, VariableSpecifications boundNames, Operator operator)
protected Restriction
TokenRelation. newLikeRestriction(TableMetadata table, VariableSpecifications boundNames, Operator operator)
protected Restriction
MultiColumnRelation. newSliceRestriction(TableMetadata table, VariableSpecifications boundNames, Bound bound, boolean inclusive)
protected abstract Restriction
Relation. newSliceRestriction(TableMetadata table, VariableSpecifications boundNames, Bound bound, boolean inclusive)
Creates a new Slice restriction instance.protected Restriction
SingleColumnRelation. newSliceRestriction(TableMetadata table, VariableSpecifications boundNames, Bound bound, boolean inclusive)
protected Restriction
TokenRelation. newSliceRestriction(TableMetadata table, VariableSpecifications boundNames, Bound bound, boolean inclusive)
Operation
Operation.Addition. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.ColumnDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.ElementDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.FieldDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
Operation
Operation.Prepend. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.RawDeletion. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata metadata)
This method validates the operation (i.e.Operation
Operation.RawUpdate. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
This method validates the operation (i.e.Operation
Operation.SetElement. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.SetField. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.SetValue. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Operation
Operation.Substraction. prepare(TableMetadata metadata, ColumnMetadata receiver, boolean canReadExistingState)
Json.Prepared
Json.Literal. prepareAndCollectMarkers(TableMetadata metadata, java.util.Collection<ColumnMetadata> receivers, VariableSpecifications boundNames)
Json.Prepared
Json.Marker. prepareAndCollectMarkers(TableMetadata metadata, java.util.Collection<ColumnMetadata> receivers, VariableSpecifications boundNames)
Json.Prepared
Json.Raw. prepareAndCollectMarkers(TableMetadata metadata, java.util.Collection<ColumnMetadata> receivers, VariableSpecifications boundNames)
protected java.util.List<ColumnMetadata>
MultiColumnRelation. receivers(TableMetadata table)
Restriction
Relation. toRestriction(TableMetadata table, VariableSpecifications boundNames)
Converts thisRelation
into aRestriction
.static void
Validation. validateKey(TableMetadata metadata, java.nio.ByteBuffer key)
Validates a (full serialized) partition key.Constructors in org.apache.cassandra.cql3 with parameters of type TableMetadata Constructor Description UpdateParameters(TableMetadata metadata, RegularAndStaticColumns updatedColumns, ClientState clientState, QueryOptions options, long timestamp, long nowInSec, int ttl, java.util.Map<DecoratedKey,Partition> prefetchedRows)
-
Uses of TableMetadata in org.apache.cassandra.cql3.conditions
Methods in org.apache.cassandra.cql3.conditions with parameters of type TableMetadata Modifier and Type Method Description ColumnCondition
ColumnCondition.Raw. prepare(java.lang.String keyspace, ColumnMetadata receiver, TableMetadata cfm)
-
Uses of TableMetadata in org.apache.cassandra.cql3.functions
Constructors in org.apache.cassandra.cql3.functions with parameters of type TableMetadata Constructor Description TokenFct(TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.cql3.restrictions
Fields in org.apache.cassandra.cql3.restrictions declared as TableMetadata Modifier and Type Field Description protected TableMetadata
TokenRestriction. metadata
TableMetadata
StatementRestrictions. table
The Column Family meta dataMethods in org.apache.cassandra.cql3.restrictions with parameters of type TableMetadata Modifier and Type Method Description void
CustomIndexExpression. addToRowFilter(RowFilter filter, TableMetadata table, QueryOptions options)
static StatementRestrictions
StatementRestrictions. empty(StatementType type, TableMetadata table)
Creates a new emptyStatementRestrictions
.boolean
TokenRestriction. hasUnrestrictedPartitionKeyComponents(TableMetadata table)
boolean
StatementRestrictions. needFiltering(TableMetadata table)
Checks if the query need to use filtering.boolean
TokenRestriction. needFiltering(TableMetadata table)
void
CustomIndexExpression. prepareValue(TableMetadata table, AbstractType<?> expressionType, VariableSpecifications boundNames)
Constructors in org.apache.cassandra.cql3.restrictions with parameters of type TableMetadata Constructor Description EQRestriction(TableMetadata table, java.util.List<ColumnMetadata> columnDefs, Term value)
SliceRestriction(TableMetadata table, java.util.List<ColumnMetadata> columnDefs, Bound bound, boolean inclusive, Term term)
StatementRestrictions(ClientState state, StatementType type, TableMetadata table, WhereClause whereClause, VariableSpecifications boundNames, java.util.List<Ordering> orderings, boolean selectsOnlyStaticColumns, boolean allowFiltering, boolean forView)
StatementRestrictions(ClientState state, StatementType type, TableMetadata table, WhereClause whereClause, VariableSpecifications boundNames, java.util.List<Ordering> orderings, boolean selectsOnlyStaticColumns, boolean allowUseOfSecondaryIndices, boolean allowFiltering, boolean forView)
TokenRestriction(TableMetadata metadata, java.util.List<ColumnMetadata> columnDefs)
Creates a newTokenRestriction
that apply to the specified columns. -
Uses of TableMetadata in org.apache.cassandra.cql3.selection
Methods in org.apache.cassandra.cql3.selection with parameters of type TableMetadata Modifier and Type Method Description ColumnMetadata
Selectable.RawIdentifier. columnMetadata(TableMetadata cfm)
protected abstract Selector
Selector.SelectorDeserializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
Selector
Selector.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
static Selection
Selection. forColumns(TableMetadata table, java.util.List<ColumnMetadata> columns, boolean returnStaticContentOnPartitionWithNoRows)
static Selection
Selection. fromSelectors(TableMetadata table, java.util.List<Selectable> selectables, VariableSpecifications boundNames, java.util.Set<ColumnMetadata> orderingColumns, java.util.Set<ColumnMetadata> nonPKRestrictedColumns, boolean hasGroupBy, boolean isJson, boolean returnStaticContentOnPartitionWithNoRows)
ColumnSpecification
Selector.Factory. getColumnSpecification(TableMetadata table)
Returns the column specification corresponding to the output value of the selector instances created by this factory.Selector.Factory
Selectable.BetweenParenthesesOrWithTuple. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithArrayLiteral. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithCast. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithElementSelection. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithFieldSelection. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithFunction. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithList. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithMapOrUdt. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithSet. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithSliceSelection. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithTerm. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithTypeHint. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WithVector. newSelectorFactory(TableMetadata cfm, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selector.Factory
Selectable.WritetimeOrTTL. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
Selectable
Selectable.BetweenParenthesesOrWithTuple.Raw. prepare(TableMetadata cfm)
Selectable
Selectable.Raw. prepare(TableMetadata table)
Selectable
Selectable.RawIdentifier. prepare(TableMetadata cfm)
Selectable
Selectable.WithArrayLiteral.Raw. prepare(TableMetadata cfm)
Selectable.WithCast
Selectable.WithCast.Raw. prepare(TableMetadata table)
Selectable.WithElementSelection
Selectable.WithElementSelection.Raw. prepare(TableMetadata cfm)
Selectable.WithFieldSelection
Selectable.WithFieldSelection.Raw. prepare(TableMetadata table)
Selectable
Selectable.WithFunction.Raw. prepare(TableMetadata table)
Selectable
Selectable.WithMapOrUdt.Raw. prepare(TableMetadata cfm)
Selectable
Selectable.WithSet.Raw. prepare(TableMetadata cfm)
Selectable.WithSliceSelection
Selectable.WithSliceSelection.Raw. prepare(TableMetadata cfm)
Selectable
Selectable.WithTerm.Raw. prepare(TableMetadata table)
Selectable
Selectable.WithTypeHint.Raw. prepare(TableMetadata cfm)
Selectable.WritetimeOrTTL
Selectable.WritetimeOrTTL.Raw. prepare(TableMetadata table)
protected AbstractType<?>
Selector.SelectorDeserializer. readType(TableMetadata metadata, DataInputPlus in)
static java.util.List<Selectable>
RawSelector. toSelectables(java.util.List<RawSelector> raws, TableMetadata table)
Converts the specified list ofRawSelector
s into a list ofSelectable
s.static Selection
Selection. wildcard(TableMetadata table, boolean isJson, boolean returnStaticContentOnPartitionWithNoRows)
static Selection
Selection. wildcardWithGroupByOrMaskedColumns(TableMetadata table, VariableSpecifications boundNames, java.util.Set<ColumnMetadata> orderingColumns, boolean isJson, boolean returnStaticContentOnPartitionWithNoRows)
Constructors in org.apache.cassandra.cql3.selection with parameters of type TableMetadata Constructor Description Selection(TableMetadata table, java.util.List<ColumnMetadata> selectedColumns, java.util.Set<ColumnMetadata> orderingColumns, SelectionColumnMapping columnMapping, org.apache.cassandra.cql3.selection.ColumnFilterFactory columnFilterFactory, boolean isJson)
WithMapOrUdt(TableMetadata cfm, java.util.List<Pair<Selectable.Raw,Selectable.Raw>> raws)
-
Uses of TableMetadata in org.apache.cassandra.cql3.statements
Fields in org.apache.cassandra.cql3.statements declared as TableMetadata Modifier and Type Field Description TableMetadata
CQL3CasRequest. metadata
TableMetadata
ModificationStatement. metadata
TableMetadata
SelectStatement. table
Methods in org.apache.cassandra.cql3.statements that return TableMetadata Modifier and Type Method Description TableMetadata
ModificationStatement. metadata()
Methods in org.apache.cassandra.cql3.statements with parameters of type TableMetadata Modifier and Type Method Description static java.nio.ByteBuffer[]
SelectStatement. getComponents(TableMetadata metadata, DecoratedKey dk)
PartitionUpdate.Builder
UpdatesCollector. getPartitionUpdateBuilder(TableMetadata metadata, DecoratedKey dk, ConsistencyLevel consistency)
protected StatementRestrictions
ModificationStatement.Parsed. newRestrictions(ClientState state, TableMetadata metadata, VariableSpecifications boundNames, Operations operations, WhereClause where, Conditions conditions, java.util.List<Ordering> orderings)
Creates the restrictions.protected ModificationStatement
DeleteStatement.Parsed. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected abstract ModificationStatement
ModificationStatement.Parsed. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedInsert. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedInsertJson. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
protected ModificationStatement
UpdateStatement.ParsedUpdate. prepareInternal(ClientState state, TableMetadata metadata, VariableSpecifications bindVariables, Conditions conditions, Attributes attrs)
static Slices
ModificationStatement. toSlices(TableMetadata metadata, java.util.SortedSet<ClusteringBound<?>> startBounds, java.util.SortedSet<ClusteringBound<?>> endBounds)
Constructors in org.apache.cassandra.cql3.statements with parameters of type TableMetadata Constructor Description CQL3CasRequest(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns conditionColumns, boolean updatesRegularRows, boolean updatesStaticRow)
ModificationStatement(StatementType type, VariableSpecifications bindVariables, TableMetadata metadata, Operations operations, StatementRestrictions restrictions, Conditions conditions, Attributes attrs)
SelectStatement(TableMetadata table, VariableSpecifications bindVariables, SelectStatement.Parameters parameters, Selection selection, StatementRestrictions restrictions, boolean isReversed, AggregationSpecification.Factory aggregationSpecFactory, org.apache.cassandra.cql3.statements.SelectStatement.ColumnComparator<java.util.List<java.nio.ByteBuffer>> orderingComparator, Term limit, Term perPartitionLimit)
-
Uses of TableMetadata in org.apache.cassandra.cql3.statements.schema
Methods in org.apache.cassandra.cql3.statements.schema with parameters of type TableMetadata Modifier and Type Method Description KeyspaceMetadata
AlterTableStatement.AlterColumn. apply(KeyspaceMetadata keyspace, TableMetadata table)
KeyspaceMetadata
AlterTableStatement.MaskColumn. apply(KeyspaceMetadata keyspace, TableMetadata table)
IndexTarget
IndexTarget.Raw. prepare(TableMetadata table)
-
Uses of TableMetadata in org.apache.cassandra.db
Fields in org.apache.cassandra.db declared as TableMetadata Modifier and Type Field Description static TableMetadata
SystemKeyspace. Batches
protected TableMetadata
UnfilteredDeserializer. metadata
Methods in org.apache.cassandra.db that return TableMetadata Modifier and Type Method Description TableMetadata
ColumnFamilyStore. metadata()
TableMetadata
ReadExecutionController. metadata()
TableMetadata
ReadQuery. metadata()
The metadata for the table this is a query on.TableMetadata
SimpleBuilders.PartitionUpdateBuilder. metadata()
TableMetadata
SinglePartitionReadQuery.Group. metadata()
Methods in org.apache.cassandra.db with parameters of type TableMetadata Modifier and Type Method Description static PartitionRangeReadCommand
PartitionRangeReadCommand. allDataRead(TableMetadata metadata, long nowInSec)
Creates a new read command that query all the data in the table.static PartitionRangeReadCommand
PartitionRangeReadCommand. create(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DataRange dataRange)
static ReadQuery
PartitionRangeReadQuery. create(TableMetadata table, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DataRange dataRange)
static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, java.nio.ByteBuffer key, Slices slices)
Creates a new single partition slice command for the provided slices.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, DecoratedKey key, java.util.NavigableSet<Clustering<?>> names)
Creates a new single partition name command for the provided rows.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, DecoratedKey key, Clustering<?> name)
Creates a new single partition name command for the provided row.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, DecoratedKey key, ColumnFilter columnFilter, ClusteringIndexFilter filter)
Creates a new read command on a single partition.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, DecoratedKey key, Slice slice)
Creates a new single partition slice command for the provided single slice.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, DecoratedKey key, Slices slices)
Creates a new single partition slice command for the provided slices.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter)
Creates a new read command on a single partition.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, Index.QueryPlan indexQueryPlan)
Creates a new read command on a single partition.static SinglePartitionReadCommand.Group
SinglePartitionReadCommand.Group. create(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, java.util.List<DecoratedKey> partitionKeys, ClusteringIndexFilter clusteringIndexFilter)
static SinglePartitionReadQuery
SinglePartitionReadQuery. create(TableMetadata metadata, long nowInSec, DecoratedKey key, ColumnFilter columnFilter, ClusteringIndexFilter filter)
Creates a new read query on a single partition.static SinglePartitionReadQuery
SinglePartitionReadQuery. create(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter)
Creates a new read query on a single partition.static UnfilteredDeserializer
UnfilteredDeserializer. create(TableMetadata metadata, DataInputPlus in, SerializationHeader header, DeserializationHelper helper)
static SinglePartitionReadQuery.Group<? extends SinglePartitionReadQuery>
SinglePartitionReadQuery. createGroup(TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, java.util.List<DecoratedKey> partitionKeys, ClusteringIndexFilter clusteringIndexFilter)
Columns
Columns.Serializer. deserialize(DataInputPlus in, TableMetadata metadata)
DataRange
DataRange.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
abstract ReadCommand
ReadCommand.SelectionDeserializer. deserialize(DataInputPlus in, int version, boolean isDigest, int digestVersion, boolean acceptsTransient, TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, Index.QueryPlan indexQueryPlan)
Slices
Slices.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
SerializationHeader
SerializationHeader.Serializer. deserializeForMessaging(DataInputPlus in, TableMetadata metadata, ColumnFilter selection, boolean hasStatic)
static ReadQuery
ReadQuery. empty(TableMetadata metadata)
static SinglePartitionReadCommand
SinglePartitionReadCommand. fullPartitionRead(TableMetadata metadata, long nowInSec, java.nio.ByteBuffer key)
Creates a new read command that queries a single partition in its entirety.static SinglePartitionReadCommand
SinglePartitionReadCommand. fullPartitionRead(TableMetadata metadata, long nowInSec, DecoratedKey key)
Creates a new read command that queries a single partition in its entirety.Directories.DataDirectory[]
Directories.DataDirectories. getDataDirectoriesFor(TableMetadata table)
Returns the data directories for the specified table.static ColumnFamilyStore
ColumnFamilyStore. getIfExists(TableMetadata table)
Returns a ColumnFamilyStore by metadata if it exists, null otherwise Differently from others, this method does not throw exception if the table does not exist.static java.util.stream.Stream<java.lang.String>
SchemaCQLHelper. getIndexesAsCQL(TableMetadata metadata, boolean ifNotExists)
Build a CQL String representation of Indexes on columns in the given Column FamilyPartitionUpdate
Mutation. getPartitionUpdate(TableMetadata table)
static java.lang.String
SchemaCQLHelper. getTableMetadataAsCQL(TableMetadata metadata, KeyspaceMetadata keyspaceMetadata)
Build a CQL String representation of Column Family Metadata.static TopPartitionTracker.StoredTopPartitions
SystemKeyspace. getTopPartitions(TableMetadata metadata, java.lang.String topType)
static java.util.stream.Stream<java.lang.String>
SchemaCQLHelper. getUserTypesAsCQL(TableMetadata metadata, Types types, boolean ifNotExists)
Build a CQL String representation of User Types used in the given table.static void
UnfilteredValidation. handleInvalid(TableMetadata metadata, DecoratedKey key, SSTableReader sstable, java.lang.String invalidContent)
boolean
DataRange. isUnrestricted(TableMetadata metadata)
Whether thisDataRange
queries everything (has no restriction neither on the partition queried, nor within the queried partition).boolean
DataRange.Paging. isUnrestricted(TableMetadata metadata)
static int
SystemKeyspace. legacyPaxosTtlSec(TableMetadata metadata)
static PaxosState.Snapshot
SystemKeyspace. loadPaxosState(DecoratedKey partitionKey, TableMetadata metadata, long nowInSec)
Load the current paxos state for the table and key NOTE: nowInSec is typically provided as zero, and should not be assumed to be definitive, as the cache may apply different nowInSec filtersstatic SerializationHeader
SerializationHeader. make(TableMetadata metadata, java.util.Collection<SSTableReader> sstables)
static SerializationHeader
SerializationHeader. makeWithoutStats(TableMetadata metadata)
static void
ExpirationDateOverflowHandling. maybeApplyExpirationDateOverflowPolicy(TableMetadata metadata, int ttl, boolean isDefaultTTL)
static void
UnfilteredValidation. maybeValidateUnfiltered(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey key, SSTableReader sstable)
void
SizeEstimatesRecorder. onDropTable(TableMetadata table, boolean dropData)
static ColumnFamilyStore
Keyspace. openAndGetStore(TableMetadata table)
static ColumnFamilyStore
Keyspace. openAndGetStoreIfExists(TableMetadata table)
static java.util.stream.Stream<java.lang.String>
SchemaCQLHelper. reCreateStatementsForSchemaCql(TableMetadata metadata, KeyspaceMetadata keyspaceMetadata)
Generates the DDL statement for aschema.cql
snapshot file.static RowIterator
EmptyIterators. row(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder)
static void
SystemKeyspace. savePaxosReadPromise(DecoratedKey key, TableMetadata metadata, Ballot ballot)
static void
SystemKeyspace. savePaxosWritePromise(DecoratedKey key, TableMetadata metadata, Ballot ballot)
static void
SystemKeyspace. saveTopPartitions(TableMetadata metadata, java.lang.String topType, java.util.Collection<TopPartitionTracker.TopPartition> topPartitions, long lastUpdate)
static void
ColumnFamilyStore. scrubDataDirectories(TableMetadata metadata)
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files and compacted sstables.void
DataRange.Serializer. serialize(DataRange range, DataOutputPlus out, int version, TableMetadata metadata)
long
DataRange.Serializer. serializedSize(DataRange range, int version, TableMetadata metadata)
default java.lang.String
Clustering. toCQLString(TableMetadata metadata)
java.lang.String
DataRange. toCQLString(TableMetadata metadata, RowFilter rowFilter)
java.lang.String
DecoratedKey. toCQLString(TableMetadata metadata)
Returns a CQL representation of this key.abstract java.lang.String
Slices. toCQLString(TableMetadata metadata, RowFilter rowFilter)
SerializationHeader
SerializationHeader.Component. toHeader(TableMetadata metadata)
default java.lang.String
Clustering. toString(TableMetadata metadata)
default java.lang.String
ClusteringBoundOrBoundary. toString(TableMetadata metadata)
java.lang.String
ClusteringPrefix. toString(TableMetadata metadata)
Generates a proper string representation of the prefix.java.lang.String
DataRange.Paging. toString(TableMetadata metadata)
java.lang.String
DataRange. toString(TableMetadata metadata)
static UnfilteredPartitionIterator
EmptyIterators. unfilteredPartition(TableMetadata metadata)
static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder)
static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder, Row staticRow, DeletionTime partitionDeletion)
PartitionUpdate.SimpleBuilder
Mutation.SimpleBuilder. update(TableMetadata metadata)
Adds an update for table identified by the provided metadata and return a builder for that partition.PartitionUpdate.SimpleBuilder
SimpleBuilders.MutationBuilder. update(TableMetadata metadata)
void
ConsistencyLevel. validateCounterForWrite(TableMetadata metadata)
Constructors in org.apache.cassandra.db with parameters of type TableMetadata Constructor Description Directories(TableMetadata metadata)
Directories(TableMetadata metadata, java.util.Collection<Directories.DataDirectory> paths)
Directories(TableMetadata metadata, Directories.DataDirectory[] paths)
Create Directories of given ColumnFamily.PartitionRangeReadCommand(boolean isDigest, int digestVersion, boolean acceptsTransient, TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DataRange dataRange, Index.QueryPlan indexQueryPlan, boolean trackWarnings)
PartitionUpdateBuilder(TableMetadata metadata, java.lang.Object... partitionKeyValues)
ReadCommand(ReadCommand.Kind kind, boolean isDigestQuery, int digestVersion, boolean acceptsTransient, TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, Index.QueryPlan indexQueryPlan, boolean trackWarnings, DataRange dataRange)
RowBuilder(TableMetadata metadata, java.lang.Object... clusteringColumns)
SerializationHeader(boolean isForSSTable, TableMetadata metadata, RegularAndStaticColumns columns, EncodingStats stats)
SinglePartitionReadCommand(boolean isDigest, int digestVersion, boolean acceptsTransient, TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, Index.QueryPlan indexQueryPlan, boolean trackWarnings, DataRange dataRange)
VirtualTableSinglePartitionReadCommand(boolean isDigest, int digestVersion, boolean acceptsTransient, TableMetadata metadata, long nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, Index.QueryPlan indexQueryPlan, boolean trackWarnings, DataRange dataRange)
-
Uses of TableMetadata in org.apache.cassandra.db.aggregation
Methods in org.apache.cassandra.db.aggregation with parameters of type TableMetadata Modifier and Type Method Description AggregationSpecification
AggregationSpecification.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.db.compaction
Methods in org.apache.cassandra.db.compaction that return TableMetadata Modifier and Type Method Description TableMetadata
UnifiedCompactionStrategy. getMetadata()
TableMetadata
CompactionInfo. getTableMetadata()
TableMetadata
CompactionIterator. metadata()
Methods in org.apache.cassandra.db.compaction with parameters of type TableMetadata Modifier and Type Method Description static CompactionInfo
CompactionInfo. withoutSSTables(TableMetadata metadata, OperationType tasktype, long completed, long total, CompactionInfo.Unit unit, TimeUUID compactionId)
Special compaction info where we always need to cancel the compaction - for example ViewBuilderTask where we don't know the sstables at constructionstatic CompactionInfo
CompactionInfo. withoutSSTables(TableMetadata metadata, OperationType tasktype, long completed, long total, CompactionInfo.Unit unit, TimeUUID compactionId, java.lang.String targetDirectory)
Special compaction info where we always need to cancel the compaction - for example AutoSavingCache where we don't know the sstables at constructionMethod parameters in org.apache.cassandra.db.compaction with type arguments of type TableMetadata Modifier and Type Method Description java.util.List<CompactionInfo.Holder>
CompactionManager. getCompactionsMatching(java.lang.Iterable<TableMetadata> columnFamilies, java.util.function.Predicate<CompactionInfo> predicate)
void
CompactionManager. interruptCompactionFor(java.lang.Iterable<TableMetadata> columnFamilies, java.util.function.Predicate<SSTableReader> sstablePredicate, boolean interruptValidation)
Try to stop all of the compactions for given ColumnFamilies.Constructors in org.apache.cassandra.db.compaction with parameters of type TableMetadata Constructor Description CompactionInfo(TableMetadata metadata, OperationType tasktype, long completed, long total, CompactionInfo.Unit unit, TimeUUID compactionId, java.util.Collection<? extends SSTableReader> sstables, java.lang.String targetDirectory)
CompactionInfo(TableMetadata metadata, OperationType tasktype, long completed, long total, TimeUUID compactionId, java.util.Collection<? extends SSTableReader> sstables)
CompactionInfo(TableMetadata metadata, OperationType tasktype, long completed, long total, TimeUUID compactionId, java.util.Collection<SSTableReader> sstables, java.lang.String targetDirectory)
-
Uses of TableMetadata in org.apache.cassandra.db.filter
Methods in org.apache.cassandra.db.filter with parameters of type TableMetadata Modifier and Type Method Description void
RowFilter. addCustomIndexExpression(TableMetadata metadata, IndexMetadata targetIndex, java.nio.ByteBuffer value)
static ColumnFilter
ColumnFilter. all(TableMetadata metadata)
A filter that includes all columns for the provided table.static ColumnFilter.Builder
ColumnFilter. allRegularColumnsBuilder(TableMetadata metadata, boolean returnStaticContentOnPartitionWithNoRows)
Returns aColumnFilter
builder that fetches all regular columns or all columns (and queries the columns added to the builder, or everything if no column is added).protected void
AbstractClusteringIndexFilter. appendOrderByToCQLString(TableMetadata metadata, java.lang.StringBuilder sb)
ClusteringIndexFilter
ClusteringIndexFilter.InternalDeserializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, boolean reversed)
ClusteringIndexFilter
ClusteringIndexFilter.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
ColumnFilter
ColumnFilter.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
ColumnSubselection
ColumnSubselection.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
DataLimits
DataLimits.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
RowFilter
RowFilter.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, boolean needsReconciliation)
protected abstract RowFilter.UserExpression
RowFilter.UserExpression.Deserializer. deserialize(DataInputPlus in, int version, TableMetadata metadata)
PartitionIterator
RowFilter. filter(PartitionIterator iter, TableMetadata metadata, long nowInSec)
Filters the provided iterator so that only the row satisfying the expression of this filter are included in the resulting iterator.protected Transformation<BaseRowIterator<?>>
RowFilter. filter(TableMetadata metadata, long nowInSec)
Note that the application of this transformation does not yet takeRowFilter.isStrict()
into account.Slices
ClusteringIndexFilter. getSlices(TableMetadata metadata)
Slices
ClusteringIndexNamesFilter. getSlices(TableMetadata metadata)
Slices
ClusteringIndexSliceFilter. getSlices(TableMetadata metadata)
protected java.nio.ByteBuffer
RowFilter.Expression. getValue(TableMetadata metadata, DecoratedKey partitionKey, Row row)
boolean
RowFilter.CustomExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
abstract boolean
RowFilter.Expression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
Returns whether the provided row satisfied this expression or not.boolean
RowFilter. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row, long nowInSec)
Whether the provided row in the provided partition satisfies this filter.boolean
RowFilter.SimpleExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
static ColumnFilter.SelectionColumnFilter
ColumnFilter.SelectionColumnFilter. newInstance(org.apache.cassandra.db.filter.ColumnFilter.FetchingStrategy fetchingStrategy, TableMetadata metadata, RegularAndStaticColumns queried, com.google.common.collect.SortedSetMultimap<ColumnIdentifier,ColumnSubselection> subSelections)
static ColumnFilter
ColumnFilter. selection(TableMetadata metadata, RegularAndStaticColumns queried, boolean returnStaticContentOnPartitionWithNoRows)
A filter that fetches all columns for the provided table, but returns only the queried ones.java.lang.String
ClusteringIndexFilter. toCQLString(TableMetadata metadata, RowFilter rowFilter)
java.lang.String
ClusteringIndexNamesFilter. toCQLString(TableMetadata metadata, RowFilter rowFilter)
java.lang.String
ClusteringIndexSliceFilter. toCQLString(TableMetadata metadata, RowFilter rowFilter)
java.lang.String
ClusteringIndexFilter. toString(TableMetadata metadata)
java.lang.String
ClusteringIndexNamesFilter. toString(TableMetadata metadata)
java.lang.String
ClusteringIndexSliceFilter. toString(TableMetadata metadata)
Constructors in org.apache.cassandra.db.filter with parameters of type TableMetadata Constructor Description CustomExpression(TableMetadata table, IndexMetadata targetIndex, java.nio.ByteBuffer value)
TombstoneOverwhelmingException(int numTombstones, java.lang.String query, TableMetadata metadata, DecoratedKey lastPartitionKey, ClusteringPrefix<?> lastClustering)
-
Uses of TableMetadata in org.apache.cassandra.db.lifecycle
Methods in org.apache.cassandra.db.lifecycle with parameters of type TableMetadata Modifier and Type Method Description static boolean
LifecycleTransaction. removeUnfinishedLeftovers(TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.db.memtable
Methods in org.apache.cassandra.db.memtable that return TableMetadata Modifier and Type Method Description TableMetadata
AbstractMemtable. metadata()
default TableMetadata
Memtable.FlushablePartitionSet. metadata()
TableMetadata
Memtable. metadata()
The table's definition metadata.TableMetadata
ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator. metadata()
Constructors in org.apache.cassandra.db.memtable with parameters of type TableMetadata Constructor Description MemtableUnfilteredPartitionIterator(TableMetadata metadata, java.util.Iterator<AtomicBTreePartition> iterator, ColumnFilter columnFilter, DataRange dataRange)
-
Uses of TableMetadata in org.apache.cassandra.db.partitions
Fields in org.apache.cassandra.db.partitions declared as TableMetadata Modifier and Type Field Description protected TableMetadata
ImmutableBTreePartition. metadata
Methods in org.apache.cassandra.db.partitions that return TableMetadata Modifier and Type Method Description abstract TableMetadata
AbstractBTreePartition. metadata()
TableMetadata
AtomicBTreePartition. metadata()
TableMetadata
ImmutableBTreePartition. metadata()
TableMetadata
Partition. metadata()
TableMetadata
PartitionUpdate.Builder. metadata()
TableMetadata
PartitionUpdate. metadata()
TableMetadata
PartitionUpdate.SimpleBuilder. metadata()
The metadata of the table this is a builder on.TableMetadata
SingletonUnfilteredPartitionIterator. metadata()
TableMetadata
UnfilteredPartitionIterator. metadata()
Methods in org.apache.cassandra.db.partitions with parameters of type TableMetadata Modifier and Type Method Description UnfilteredPartitionIterator
UnfilteredPartitionIterators.Serializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, ColumnFilter selection, DeserializationHelper.Flag flag)
static PartitionUpdate
PartitionUpdate. emptyUpdate(TableMetadata metadata, DecoratedKey key)
Creates a empty immutable partition update.static PartitionUpdate
PartitionUpdate. fullPartitionDelete(TableMetadata metadata, java.nio.ByteBuffer key, long timestamp, long nowInSec)
Creates a partition update that entirely deletes a given partition.static PartitionUpdate
PartitionUpdate. fullPartitionDelete(TableMetadata metadata, DecoratedKey key, long timestamp, long nowInSec)
Creates an immutable partition update that entirely deletes a given partition.static PartitionUpdate.SimpleBuilder
PartitionUpdate. simpleBuilder(TableMetadata metadata, java.lang.Object... partitionKeyValues)
Creates a new simple partition update builder.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, java.nio.ByteBuffer key, Row row)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, DecoratedKey key, Row row)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, DecoratedKey key, Row row, Row staticRow)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. unsafeConstruct(TableMetadata metadata, DecoratedKey key, BTreePartitionData holder, MutableDeletionInfo deletionInfo, boolean canHaveShadowedData)
Constructors in org.apache.cassandra.db.partitions with parameters of type TableMetadata Constructor Description Builder(TableMetadata metadata, java.nio.ByteBuffer key, RegularAndStaticColumns columns, int initialRowCapacity)
Builder(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns columnDefinitions, int size)
Builder(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns columns, int initialRowCapacity, boolean canHaveShadowedData)
ImmutableBTreePartition(TableMetadata metadata, DecoratedKey partitionKey, BTreePartitionData holder)
ImmutableBTreePartition(TableMetadata metadata, DecoratedKey partitionKey, RegularAndStaticColumns columns, Row staticRow, java.lang.Object[] tree, DeletionInfo deletionInfo, EncodingStats stats)
-
Uses of TableMetadata in org.apache.cassandra.db.repair
Methods in org.apache.cassandra.db.repair that return TableMetadata Modifier and Type Method Description TableMetadata
CassandraValidationIterator. metadata()
-
Uses of TableMetadata in org.apache.cassandra.db.rows
Fields in org.apache.cassandra.db.rows declared as TableMetadata Modifier and Type Field Description protected TableMetadata
AbstractUnfilteredRowIterator. metadata
Methods in org.apache.cassandra.db.rows that return TableMetadata Modifier and Type Method Description TableMetadata
AbstractUnfilteredRowIterator. metadata()
TableMetadata
BaseRowIterator. metadata()
The metadata for the table this iterator on.TableMetadata
LazilyInitializedUnfilteredRowIterator. metadata()
TableMetadata
UnfilteredRowIteratorWithLowerBound. metadata()
default TableMetadata
WrappingUnfilteredRowIterator. metadata()
Methods in org.apache.cassandra.db.rows with parameters of type TableMetadata Modifier and Type Method Description java.lang.Iterable<Cell<?>>
BTreeRow. cellsInLegacyOrder(TableMetadata metadata, boolean reversed)
java.lang.Iterable<Cell<?>>
Row. cellsInLegacyOrder(TableMetadata metadata, boolean reversed)
An iterable over the cells of this row that return cells in "legacy order".UnfilteredRowIterator
UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, ColumnFilter selection, DeserializationHelper.Flag flag)
UnfilteredRowIterator
UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, DeserializationHelper.Flag flag, UnfilteredRowIteratorSerializer.Header header)
UnfilteredRowIteratorSerializer.Header
UnfilteredRowIteratorSerializer. deserializeHeader(TableMetadata metadata, ColumnFilter selection, DataInputPlus in, int version, DeserializationHelper.Flag flag)
Row
BTreeRow. filter(ColumnFilter filter, DeletionTime activeDeletion, boolean setActiveDeletionToRow, TableMetadata metadata)
Row
BTreeRow. filter(ColumnFilter filter, TableMetadata metadata)
Row
Row. filter(ColumnFilter filter, DeletionTime activeDeletion, boolean setActiveDeletionToRow, TableMetadata metadata)
Returns a copy of this row that: 1) only includes the data for the column included byfilter
.Row
Row. filter(ColumnFilter filter, TableMetadata metadata)
Returns a copy of this row that: 1) only includes the data for the column included byfilter
.static UnfilteredRowIterator
UnfilteredRowIterators. noRowsIterator(TableMetadata metadata, DecoratedKey partitionKey, Row staticRow, DeletionTime partitionDeletion, boolean isReverseOrder)
Returns an empty unfiltered iterator for a given partition.static Row.SimpleBuilder
Rows. simpleBuilder(TableMetadata metadata, java.lang.Object... clusteringValues)
Creates a new simple row builder.static UnfilteredRowIterator
UnfilteredRowIterators. singleton(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats encodingStats)
java.lang.String
AbstractRangeTombstoneMarker. toString(TableMetadata metadata, boolean fullDetails)
java.lang.String
AbstractRangeTombstoneMarker. toString(TableMetadata metadata, boolean includeClusteringKeys, boolean fullDetails)
java.lang.String
AbstractRow. toString(TableMetadata metadata)
java.lang.String
AbstractRow. toString(TableMetadata metadata, boolean fullDetails)
java.lang.String
AbstractRow. toString(TableMetadata metadata, boolean includeClusterKeys, boolean fullDetails)
java.lang.String
ArtificialBoundMarker. toString(TableMetadata metadata)
java.lang.String
RangeTombstoneBoundaryMarker. toString(TableMetadata metadata)
java.lang.String
RangeTombstoneBoundMarker. toString(TableMetadata metadata)
java.lang.String
Row. toString(TableMetadata metadata, boolean fullDetails)
java.lang.String
Unfiltered. toString(TableMetadata metadata)
java.lang.String
Unfiltered. toString(TableMetadata metadata, boolean fullDetails)
java.lang.String
Unfiltered. toString(TableMetadata metadata, boolean includeClusterKeys, boolean fullDetails)
void
AbstractRangeTombstoneMarker. validateData(TableMetadata metadata)
void
AbstractRow. validateData(TableMetadata metadata)
void
Unfiltered. validateData(TableMetadata metadata)
Validate the data of this atom.Constructors in org.apache.cassandra.db.rows with parameters of type TableMetadata Constructor Description AbstractUnfilteredRowIterator(TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats stats)
DeserializationHelper(TableMetadata metadata, int version, DeserializationHelper.Flag flag)
DeserializationHelper(TableMetadata metadata, int version, DeserializationHelper.Flag flag, ColumnFilter columnsToFetch)
RowAndDeletionMergeIterator(TableMetadata 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)
-
Uses of TableMetadata in org.apache.cassandra.db.streaming
Methods in org.apache.cassandra.db.streaming that return TableMetadata Modifier and Type Method Description TableMetadata
CassandraStreamReader.StreamDeserializer. metadata()
Methods in org.apache.cassandra.db.streaming with parameters of type TableMetadata Modifier and Type Method Description protected CassandraStreamReader.StreamDeserializer
CassandraStreamReader. getDeserializer(TableMetadata metadata, TrackedDataInputPlus in, Version inputVersion, StreamSession session, SSTableMultiWriter writer)
protected SerializationHeader
CassandraStreamReader. getHeader(TableMetadata metadata)
Constructors in org.apache.cassandra.db.streaming with parameters of type TableMetadata Constructor Description StreamDeserializer(TableMetadata metadata, DataInputPlus in, Version version, SerializationHeader header, StreamSession session, SSTableMultiWriter writer)
-
Uses of TableMetadata in org.apache.cassandra.db.transform
Methods in org.apache.cassandra.db.transform that return TableMetadata Modifier and Type Method Description TableMetadata
BaseRows. metadata()
-
Uses of TableMetadata in org.apache.cassandra.db.virtual
Fields in org.apache.cassandra.db.virtual declared as TableMetadata Modifier and Type Field Description protected TableMetadata
AbstractVirtualTable. metadata
Methods in org.apache.cassandra.db.virtual that return TableMetadata Modifier and Type Method Description TableMetadata
VirtualKeyspaceRegistry. getTableMetadataNullable(TableId id)
TableMetadata
AbstractVirtualTable. metadata()
TableMetadata
VirtualTable. metadata()
Returns the view metadata.Methods in org.apache.cassandra.db.virtual with parameters of type TableMetadata Modifier and Type Method Description static AbstractMutableVirtualTable.ColumnValues
AbstractMutableVirtualTable.ColumnValues. from(TableMetadata metadata, ClusteringPrefix<?> prefix)
Returns the set of column values corresponding to the specified clustering prefix.static AbstractMutableVirtualTable.ColumnValues
AbstractMutableVirtualTable.ColumnValues. from(TableMetadata metadata, DecoratedKey partitionKey)
Returns the set of column values corresponding to the specified partition key.UnfilteredRowIterator
AbstractVirtualTable.Partition. toRowIterator(TableMetadata metadata, ClusteringIndexFilter clusteringIndexFilter, ColumnFilter columnFilter, long now)
Constructors in org.apache.cassandra.db.virtual with parameters of type TableMetadata Constructor Description AbstractMutableVirtualTable(TableMetadata metadata)
AbstractVirtualTable(TableMetadata metadata)
SimpleDataSet(TableMetadata metadata)
SimpleDataSet(TableMetadata metadata, java.util.Comparator<DecoratedKey> comparator)
SimpleTable(TableMetadata metadata, java.util.function.Supplier<AbstractVirtualTable.DataSet> supplier)
-
Uses of TableMetadata in org.apache.cassandra.exceptions
Constructors in org.apache.cassandra.exceptions with parameters of type TableMetadata Constructor Description UnknownIndexException(TableMetadata metadata, java.util.UUID id)
-
Uses of TableMetadata in org.apache.cassandra.index
Methods in org.apache.cassandra.index with parameters of type TableMetadata Modifier and Type Method Description SSTableFlushObserver
Index.Group. getFlushObserver(Descriptor descriptor, LifecycleNewTracker tracker, TableMetadata tableMetadata)
Get flush observer to observe partition/cell events generated by flushing SSTable (memtable flush or compaction).SSTableFlushObserver
SingletonIndexGroup. getFlushObserver(Descriptor descriptor, LifecycleNewTracker tracker, TableMetadata tableMetadata)
static IndexRegistry
IndexRegistry. obtain(TableMetadata table)
Returns theIndexRegistry
associated to the specified table.static Pair<ColumnMetadata,IndexTarget.Type>
TargetParser. parse(TableMetadata metadata, java.lang.String target)
static Pair<ColumnMetadata,IndexTarget.Type>
TargetParser. parse(TableMetadata metadata, IndexMetadata indexDef)
-
Uses of TableMetadata in org.apache.cassandra.index.internal
Methods in org.apache.cassandra.index.internal that return TableMetadata Modifier and Type Method Description static TableMetadata
CassandraIndex. indexCfsMetadata(TableMetadata baseCfsMetadata, IndexMetadata indexMetadata)
Construct the TableMetadata for an index table, the clustering columns in the index table vary dependent on the kind of the indexed value.Methods in org.apache.cassandra.index.internal with parameters of type TableMetadata Modifier and Type Method Description default TableMetadata.Builder
CassandraIndexFunctions. addIndexClusteringColumns(TableMetadata.Builder builder, TableMetadata baseMetadata, ColumnMetadata cfDef)
Add the clustering columns for a specific type of index table to the a TableMetadata.Builder (which is being used to construct the index table's TableMetadata.static TableMetadata
CassandraIndex. indexCfsMetadata(TableMetadata baseCfsMetadata, IndexMetadata indexMetadata)
Construct the TableMetadata for an index table, the clustering columns in the index table vary dependent on the kind of the indexed value. -
Uses of TableMetadata in org.apache.cassandra.index.sai
Methods in org.apache.cassandra.index.sai that return TableMetadata Modifier and Type Method Description TableMetadata
StorageAttachedIndexGroup. metadata()
Methods in org.apache.cassandra.index.sai with parameters of type TableMetadata Modifier and Type Method Description SSTableFlushObserver
StorageAttachedIndexGroup. getFlushObserver(Descriptor descriptor, LifecycleNewTracker tracker, TableMetadata tableMetadata)
static java.util.Map<java.lang.String,java.lang.String>
StorageAttachedIndex. validateOptions(java.util.Map<java.lang.String,java.lang.String> options, TableMetadata metadata)
Used via reflection inIndexMetadata
-
Uses of TableMetadata in org.apache.cassandra.index.sai.metrics
Constructors in org.apache.cassandra.index.sai.metrics with parameters of type TableMetadata Constructor Description IndexGroupMetrics(TableMetadata table, StorageAttachedIndexGroup group)
PerQueryMetrics(TableMetadata table)
TableQueryMetrics(TableMetadata table)
TableStateMetrics(TableMetadata table, StorageAttachedIndexGroup group)
-
Uses of TableMetadata in org.apache.cassandra.index.sai.plan
Methods in org.apache.cassandra.index.sai.plan that return TableMetadata Modifier and Type Method Description TableMetadata
QueryController. metadata()
-
Uses of TableMetadata in org.apache.cassandra.index.sai.utils
Methods in org.apache.cassandra.index.sai.utils that return TableMetadata Modifier and Type Method Description TableMetadata
InMemoryUnfilteredPartitionIterator. metadata()
-
Uses of TableMetadata in org.apache.cassandra.index.sasi
Methods in org.apache.cassandra.index.sasi with parameters of type TableMetadata Modifier and Type Method Description static java.util.Map<java.lang.String,java.lang.String>
SASIIndex. validateOptions(java.util.Map<java.lang.String,java.lang.String> options, TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.index.sasi.plan
Methods in org.apache.cassandra.index.sasi.plan that return TableMetadata Modifier and Type Method Description TableMetadata
QueryController. metadata()
-
Uses of TableMetadata in org.apache.cassandra.io.sstable
Fields in org.apache.cassandra.io.sstable declared as TableMetadata Modifier and Type Field Description protected TableMetadata
AbstractSSTableIterator. metadata
Methods in org.apache.cassandra.io.sstable that return TableMetadata Modifier and Type Method Description TableMetadata
AbstractSSTableIterator. metadata()
TableMetadata
EmptySSTableScanner. metadata()
TableMetadata
SSTable. metadata()
TableMetadata
SSTableIdentityIterator. metadata()
Methods in org.apache.cassandra.io.sstable with parameters of type TableMetadata Modifier and Type Method Description static SSTableSimpleIterator
SSTableSimpleIterator. create(TableMetadata metadata, DataInputPlus in, SerializationHeader header, DeserializationHelper helper, DeletionTime partitionDeletion)
static SSTableSimpleIterator
SSTableSimpleIterator. createTombstoneOnly(TableMetadata metadata, DataInputPlus in, SerializationHeader header, DeserializationHelper helper, DeletionTime partitionDeletion)
Constructors in org.apache.cassandra.io.sstable with parameters of type TableMetadata Constructor Description EmptySSTableSimpleIterator(TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.io.sstable.format
Methods in org.apache.cassandra.io.sstable.format that return TableMetadata Modifier and Type Method Description TableMetadata
SSTableScanner. metadata()
Methods in org.apache.cassandra.io.sstable.format with parameters of type TableMetadata Modifier and Type Method Description static SequentialWriter
DataComponent. buildWriter(Descriptor descriptor, TableMetadata metadata, SequentialWriterOption options, MetadataCollector metadataCollector, OperationType operationType, Config.FlushCompression flushCompression)
static IFilter
FilterComponent. maybeLoadBloomFilter(Descriptor descriptor, java.util.Set<Component> components, TableMetadata metadata, ValidationMetadata validationMetadata)
Optionally loads a Bloom filter.SerializationHeader
StatsComponent. serializationHeader(TableMetadata metadata)
protected void
SSTableReaderLoadingBuilder. validatePartitioner(TableMetadata metadata, ValidationMetadata validationMetadata)
Check if sstable is created using same partitioner. -
Uses of TableMetadata in org.apache.cassandra.io.sstable.format.big
Methods in org.apache.cassandra.io.sstable.format.big with parameters of type TableMetadata Modifier and Type Method Description static IndexSummaryComponent
IndexSummaryComponent. load(File summaryFile, TableMetadata metadata)
Load index summary, first key and last key from Summary.db file if it exists.static IndexSummaryComponent
IndexSummaryComponent. loadOrDeleteCorrupted(File summaryFile, TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.locator
Methods in org.apache.cassandra.locator with parameters of type TableMetadata Modifier and Type Method Description static EndpointsForToken
EndpointsForToken. natural(TableMetadata table, Token token)
static EndpointsForToken
EndpointsForToken. pending(TableMetadata table, Token token)
-
Uses of TableMetadata in org.apache.cassandra.metrics
Methods in org.apache.cassandra.metrics with parameters of type TableMetadata Modifier and Type Method Description java.util.Map<java.lang.String,java.lang.Long>
TopPartitionTracker.TopHolder. toMap(TableMetadata metadata)
Constructors in org.apache.cassandra.metrics with parameters of type TableMetadata Constructor Description TopPartitionTracker(TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.schema
Subclasses of TableMetadata in org.apache.cassandra.schema Modifier and Type Class Description static class
TableMetadata.CompactTableMetadata
Fields in org.apache.cassandra.schema declared as TableMetadata Modifier and Type Field Description TableMetadata
ViewMetadata. metadata
static TableMetadata
SystemDistributedKeyspace. PartitionDenylistTable
Methods in org.apache.cassandra.schema that return TableMetadata Modifier and Type Method Description TableMetadata
ViewMetadata. baseTableMetadata()
TableMetadata
TableMetadata.Builder. build()
TableMetadata
TableMetadataRef. get()
default TableMetadata
SchemaProvider. getExistingTableMetadata(TableId id)
TableMetadata
TableMetadataRef. getLocal()
Returns node-local table metadataTableMetadata
Tables. getNullable(java.lang.String name)
Get the table with the specified nameTableMetadata
Tables. getNullable(TableId id)
TableMetadata
Schema. getTableMetadata(java.lang.String keyspace, java.lang.String table)
Given a keyspace name and table name, get the table meta data.TableMetadata
Schema. getTableMetadata(Descriptor descriptor)
TableMetadata
Schema. getTableMetadata(TableId id)
TableMetadata
SchemaProvider. getTableMetadata(java.lang.String keyspace, java.lang.String table)
TableMetadata
SchemaProvider. getTableMetadata(TableId id)
TableMetadata
KeyspaceMetadata. getTableNullable(java.lang.String tableName)
TableMetadata
KeyspaceMetadata. getTableOrViewNullable(java.lang.String tableOrViewName)
TableMetadata
Keyspaces. getTableOrViewNullable(TableId id)
static TableMetadata
TableMetadata. minimal(java.lang.String keyspace, java.lang.String name)
There is a couple of places in the code where we need a TableMetadata object and don't have one readily available and know that only the keyspace and name matter.TableMetadata
TableMetadata. updateIndexTableMetadata(TableParams baseTableParams)
TableMetadata
Schema. validateTable(java.lang.String keyspaceName, java.lang.String tableName)
TableMetadata
TableMetadata. withSwapped(java.util.Set<TableMetadata.Flag> flags)
TableMetadata
TableMetadata. withSwapped(Indexes indexes)
TableMetadata
TableMetadata. withSwapped(TableParams params)
TableMetadata
TableMetadata. withSwapped(Triggers triggers)
TableMetadata
TableMetadata. withUpdatedUserType(UserType udt)
Methods in org.apache.cassandra.schema that return types with arguments of type TableMetadata Modifier and Type Method Description java.util.Optional<TableMetadata>
KeyspaceMetadata. findIndexedTable(java.lang.String indexName)
java.util.Optional<TableMetadata>
Tables. get(java.lang.String name)
Get the table with the specified namejava.lang.Iterable<TableMetadata>
Schema. getTablesAndViews(java.lang.String keyspaceName)
Get metadata about keyspace inner ColumnFamiliesjava.util.Iterator<TableMetadata>
Tables. iterator()
java.lang.Iterable<TableMetadata>
Tables. referencingUserType(java.nio.ByteBuffer name)
java.util.stream.Stream<TableMetadata>
Tables. stream()
java.lang.Iterable<TableMetadata>
KeyspaceMetadata. tablesAndViews()
java.util.stream.Stream<TableMetadata>
KeyspaceMetadata. tablesUsingFunction(Function function)
Methods in org.apache.cassandra.schema with parameters of type TableMetadata Modifier and Type Method Description Tables.Builder
Tables.Builder. add(TableMetadata table)
Tables.Builder
Tables.Builder. add(TableMetadata... tables)
static SchemaTransformation
SchemaTransformations. addTable(TableMetadata table, boolean ignoreIfExists)
Creates a schema transformation that adds the provided table.void
IndexMetadata. appendCqlTo(CqlBuilder builder, TableMetadata table, boolean ifNotExists)
Appends to the specified builder the CQL used to create this index.static ColumnMetadata
ColumnMetadata. clusteringColumn(TableMetadata table, java.nio.ByteBuffer name, AbstractType<?> type, int position)
ViewMetadata
ViewMetadata. copy(TableMetadata newMetadata)
IndexMetadata
IndexMetadata.Serializer. deserialize(DataInputPlus in, int version, TableMetadata table)
static TableMetadataRef
TableMetadataRef. forOfflineTools(TableMetadata metadata)
Create a new ref to the passedTableMetadata
for use by offline tools only.Selector.Factory
ColumnMetadata. newSelectorFactory(TableMetadata table, AbstractType<?> expectedType, java.util.List<ColumnMetadata> defs, VariableSpecifications boundNames)
static Tables
Tables. of(TableMetadata... tables)
default void
SchemaChangeListener. onAlterTable(TableMetadata before, TableMetadata after, boolean affectStatements)
default void
SchemaChangeListener. onCreateTable(TableMetadata table)
default void
SchemaChangeListener. onDropTable(TableMetadata table, boolean dropData)
default void
SchemaChangeListener. onPreAlterTable(TableMetadata before, TableMetadata after)
static ColumnMetadata
ColumnMetadata. partitionKeyColumn(TableMetadata table, java.nio.ByteBuffer name, AbstractType<?> type, int position)
static ColumnMetadata
ColumnMetadata. regularColumn(TableMetadata table, java.nio.ByteBuffer name, AbstractType<?> type)
void
TableMetadataRef. setLocalOverrides(TableMetadata metadata)
static ColumnMetadata
ColumnMetadata. staticColumn(TableMetadata table, java.nio.ByteBuffer name, AbstractType<?> type)
java.lang.String
IndexMetadata. toCqlString(TableMetadata table, boolean ifNotExists)
void
Indexes. validate(TableMetadata table)
void
IndexMetadata. validate(TableMetadata table)
void
TableMetadata. validateCompatibility(TableMetadata previous)
Tables
Tables. with(TableMetadata table)
Create a Tables instance with the provided table addedTables
Tables. without(TableMetadata table)
Tables
Tables. withSwapped(TableMetadata table)
Method parameters in org.apache.cassandra.schema with type arguments of type TableMetadata Modifier and Type Method Description Tables.Builder
Tables.Builder. add(java.lang.Iterable<TableMetadata> tables)
Tables
Tables. filter(java.util.function.Predicate<TableMetadata> predicate)
static Tables
Tables. of(java.lang.Iterable<TableMetadata> tables)
Constructors in org.apache.cassandra.schema with parameters of type TableMetadata Constructor Description ColumnMetadata(TableMetadata table, java.nio.ByteBuffer name, AbstractType<?> type, int position, ColumnMetadata.Kind kind, ColumnMask mask)
ViewMetadata(TableId baseTableId, java.lang.String baseTableName, boolean includeAllColumns, WhereClause whereClause, TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.service
Methods in org.apache.cassandra.service with parameters of type TableMetadata Modifier and Type Method Description void
ClientState. ensureTablePermission(TableMetadata table, Permission perm)
boolean
ClientState. hasTablePermission(TableMetadata table, Permission perm)
void
CacheService. invalidateCounterCacheForCf(TableMetadata tableMetadata)
void
CacheService. invalidateKeyCacheForCf(TableMetadata tableMetadata)
void
CacheService. invalidateRowCacheForCf(TableMetadata tableMetadata)
-
Uses of TableMetadata in org.apache.cassandra.service.pager
Methods in org.apache.cassandra.service.pager with parameters of type TableMetadata Modifier and Type Method Description Clustering<?>
PagingState.RowMark. clustering(TableMetadata metadata)
static PagingState.RowMark
PagingState.RowMark. create(TableMetadata metadata, Row row, ProtocolVersion protocolVersion)
-
Uses of TableMetadata in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos with parameters of type TableMetadata Modifier and Type Method Description static PaxosRepair
PaxosRepair. create(ConsistencyLevel consistency, DecoratedKey partitionKey, Ballot incompleteBallot, TableMetadata table)
static Commit.Proposal
Commit.Proposal. empty(Ballot ballot, DecoratedKey partitionKey, TableMetadata metadata)
static Commit
Commit. emptyCommit(DecoratedKey partitionKey, TableMetadata metadata)
static PaxosState
PaxosState. get(DecoratedKey partitionKey, TableMetadata table)
static boolean
Paxos. isInRangeAndShouldProcess(InetAddressAndPort from, DecoratedKey key, TableMetadata table, boolean includesRead)
static PaxosOperationLock
PaxosState. lock(DecoratedKey partitionKey, TableMetadata metadata, long deadline, ConsistencyLevel consistencyForConsensus, boolean isWrite)
static Commit
Commit. newPrepare(DecoratedKey partitionKey, TableMetadata metadata, Ballot ballot)
static Commit.Accepted
Commit.Accepted. none(DecoratedKey partitionKey, TableMetadata metadata)
static Commit.Committed
Commit.Committed. none(DecoratedKey partitionKey, TableMetadata metadata)
static PaxosState.Snapshot
PaxosState. unsafeGetIfPresent(DecoratedKey partitionKey, TableMetadata metadata)
static boolean
PaxosRepair. validatePeerCompatibility(SharedContext ctx, TableMetadata table, java.util.Collection<Range<Token>> ranges)
Constructors in org.apache.cassandra.service.paxos with parameters of type TableMetadata Constructor Description Key(DecoratedKey partitionKey, TableMetadata metadata)
-
Uses of TableMetadata in org.apache.cassandra.service.paxos.cleanup
Methods in org.apache.cassandra.service.paxos.cleanup with parameters of type TableMetadata Modifier and Type Method Description static PaxosCleanup
PaxosCleanup. cleanup(SharedContext ctx, java.util.Collection<InetAddressAndPort> endpoints, TableMetadata table, java.util.Collection<Range<Token>> ranges, boolean skippedReplicas, java.util.concurrent.Executor executor)
Constructors in org.apache.cassandra.service.paxos.cleanup with parameters of type TableMetadata Constructor Description PaxosCleanup(SharedContext ctx, java.util.Collection<InetAddressAndPort> endpoints, TableMetadata table, java.util.Collection<Range<Token>> ranges, boolean skippedReplicas, java.util.concurrent.Executor executor)
-
Uses of TableMetadata in org.apache.cassandra.service.paxos.uncommitted
Methods in org.apache.cassandra.service.paxos.uncommitted with parameters of type TableMetadata Modifier and Type Method Description static Commit.Committed
PaxosRows. getCommitted(TableMetadata metadata, DecoratedKey partitionKey, Row row, long purgeBefore, long overrideTtlSeconds)
-
Uses of TableMetadata in org.apache.cassandra.service.paxos.v1
Constructors in org.apache.cassandra.service.paxos.v1 with parameters of type TableMetadata Constructor Description PrepareCallback(DecoratedKey key, TableMetadata metadata, int targets, ConsistencyLevel consistency, Dispatcher.RequestTime requestTime)
-
Uses of TableMetadata in org.apache.cassandra.service.reads.range
Methods in org.apache.cassandra.service.reads.range with parameters of type TableMetadata Modifier and Type Method Description static boolean
RangeCommands. sufficientLiveNodesForSelectStar(TableMetadata metadata, ConsistencyLevel consistency)
Added specifically to check for sufficient nodes live to serve partition denylist queries -
Uses of TableMetadata in org.apache.cassandra.tools
Methods in org.apache.cassandra.tools that return TableMetadata Modifier and Type Method Description static TableMetadata
Util. metadataFromSSTable(Descriptor desc)
Construct table schema from info stored in SSTable's Stats.dbMethods in org.apache.cassandra.tools with parameters of type TableMetadata Modifier and Type Method Description static void
JsonTransformer. keysToJson(ISSTableScanner currentScanner, java.util.stream.Stream<DecoratedKey> keys, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
static void
JsonTransformer. toJson(ISSTableScanner currentScanner, java.util.stream.Stream<UnfilteredRowIterator> partitions, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
static void
JsonTransformer. toJsonLines(ISSTableScanner currentScanner, java.util.stream.Stream<UnfilteredRowIterator> partitions, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
-
Uses of TableMetadata in org.apache.cassandra.transport
Methods in org.apache.cassandra.transport with parameters of type TableMetadata Modifier and Type Method Description void
Server.EventNotifier. onAlterTable(TableMetadata before, TableMetadata after, boolean affectsStatements)
void
Server.EventNotifier. onCreateTable(TableMetadata table)
void
Server.EventNotifier. onDropTable(TableMetadata table, boolean dropData)
-
Uses of TableMetadata in org.apache.cassandra.utils
Methods in org.apache.cassandra.utils with parameters of type TableMetadata Modifier and Type Method Description static void
DiagnosticSnapshotService. duplicateRows(TableMetadata metadata, java.lang.Iterable<InetAddressAndPort> replicas)
static void
DiagnosticSnapshotService. repairedDataMismatch(TableMetadata metadata, java.lang.Iterable<InetAddressAndPort> replicas)
static void
DiagnosticSnapshotService. repairedDataMismatch(TableMetadata metadata, java.lang.Iterable<InetAddressAndPort> replicas, java.util.List<Range<Token>> ranges)
-