Uses of Class
org.apache.cassandra.schema.TableId
-
-
Uses of TableId in org.apache.cassandra.cache
Fields in org.apache.cassandra.cache declared as TableId Modifier and Type Field Description TableId
CacheKey. tableId
Constructors in org.apache.cassandra.cache with parameters of type TableId Constructor Description CacheKey(TableId tableId, java.lang.String indexName)
RowCacheKey(TableId tableId, java.lang.String indexName, byte[] key)
RowCacheKey(TableId tableId, java.lang.String indexName, java.nio.ByteBuffer key)
-
Uses of TableId in org.apache.cassandra.cql3.statements.schema
Methods in org.apache.cassandra.cql3.statements.schema that return TableId Modifier and Type Method Description TableId
TableAttributes. getId()
-
Uses of TableId in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return types with arguments of type TableId Modifier and Type Method Description java.util.Collection<TableId>
CounterMutation. getTableIds()
java.util.Collection<TableId>
IMutation. getTableIds()
java.util.Collection<TableId>
Mutation. getTableIds()
Methods in org.apache.cassandra.db with parameters of type TableId Modifier and Type Method Description void
Keyspace. dropCf(TableId tableId)
ColumnFamilyStore
Keyspace. getColumnFamilyStore(TableId id)
static ColumnFamilyStore
ColumnFamilyStore. getIfExists(TableId id)
Returns a ColumnFamilyStore by id if it exists, null otherwise Differently from others, this method does not throw exception if the table does not exist.static long
SystemKeyspace. getTruncatedAt(TableId id)
static CommitLogPosition
SystemKeyspace. getTruncatedPosition(TableId id)
boolean
Keyspace. hasColumnFamilyStore(TableId id)
static TableMetrics
ColumnFamilyStore. metricsFor(TableId tableId)
static void
SystemKeyspace. removeTruncationRecord(TableId id)
This method is used to remove information about truncation time for specified column familyvoid
StorageHook. reportRead(TableId tableId, DecoratedKey key)
void
StorageHook. reportWrite(TableId tableId, PartitionUpdate partitionUpdate)
Mutation
Mutation. without(TableId tableId)
Method parameters in org.apache.cassandra.db with type arguments of type TableId Modifier and Type Method Description Mutation
Mutation. without(java.util.Set<TableId> tableIds)
Constructor parameters in org.apache.cassandra.db with type arguments of type TableId Constructor Description Mutation(java.lang.String keyspaceName, DecoratedKey key, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications, long approxCreatedAtNanos)
Mutation(java.lang.String keyspaceName, DecoratedKey key, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications, long approxCreatedAtNanos, boolean cdcEnabled)
-
Uses of TableId in org.apache.cassandra.db.commitlog
Methods in org.apache.cassandra.db.commitlog that return types with arguments of type TableId Modifier and Type Method Description java.util.Collection<TableId>
CommitLogSegment. getDirtyTableIds()
java.util.Set<java.util.Map.Entry<TableId,java.util.concurrent.atomic.AtomicInteger>>
CommitLogReader. getInvalidMutations()
Methods in org.apache.cassandra.db.commitlog with parameters of type TableId Modifier and Type Method Description void
CommitLog. discardCompletedSegments(TableId id, CommitLogPosition lowerBound, CommitLogPosition upperBound)
Modifies the per-CF dirty cursors of any commit log segments for the column family according to the position given.void
CommitLogSegment. markClean(TableId tableId, CommitLogPosition startPosition, CommitLogPosition endPosition)
Marks the ColumnFamily specified by id as clean for this log segment.Method parameters in org.apache.cassandra.db.commitlog with type arguments of type TableId Modifier and Type Method Description void
CommitLog. forceRecycleAllSegments(java.lang.Iterable<TableId> droppedTables)
Flushes all dirty CFs, waiting for them to free and recycle any segments they were retaining -
Uses of TableId in org.apache.cassandra.db.streaming
Fields in org.apache.cassandra.db.streaming declared as TableId Modifier and Type Field Description TableId
CassandraStreamHeader. tableId
protected TableId
CassandraStreamReader. tableId
Methods in org.apache.cassandra.db.streaming that return TableId Modifier and Type Method Description TableId
CassandraIncomingFile. getTableId()
TableId
CassandraOutgoingFile. getTableId()
Methods in org.apache.cassandra.db.streaming with parameters of type TableId Modifier and Type Method Description CassandraStreamHeader.Builder
CassandraStreamHeader.Builder. withTableId(TableId tableId)
Method parameters in org.apache.cassandra.db.streaming with type arguments of type TableId Modifier and Type Method Description CassandraStreamHeader
CassandraStreamHeader.CassandraStreamHeaderSerializer. deserialize(DataInputPlus in, int version, java.util.function.Function<TableId,IPartitioner> partitionerMapper)
-
Uses of TableId in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view with parameters of type TableId Modifier and Type Method Description TableViews
ViewManager. forTable(TableId id)
Constructors in org.apache.cassandra.db.view with parameters of type TableId Constructor Description TableViews(TableId id)
-
Uses of TableId in org.apache.cassandra.db.virtual
Methods in org.apache.cassandra.db.virtual that return types with arguments of type TableId Modifier and Type Method Description java.util.Collection<TableId>
VirtualMutation. getTableIds()
Methods in org.apache.cassandra.db.virtual with parameters of type TableId Modifier and Type Method Description TableMetadata
VirtualKeyspaceRegistry. getTableMetadataNullable(TableId id)
VirtualTable
VirtualKeyspaceRegistry. getTableNullable(TableId id)
Constructor parameters in org.apache.cassandra.db.virtual with type arguments of type TableId Constructor Description VirtualMutation(java.lang.String keyspaceName, DecoratedKey partitionKey, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications)
-
Uses of TableId in org.apache.cassandra.exceptions
Fields in org.apache.cassandra.exceptions declared as TableId Modifier and Type Field Description TableId
UnknownTableException. id
Constructors in org.apache.cassandra.exceptions with parameters of type TableId Constructor Description UnknownTableException(java.lang.String msg, TableId id)
-
Uses of TableId in org.apache.cassandra.io.sstable
Methods in org.apache.cassandra.io.sstable that return TableId Modifier and Type Method Description TableId
SimpleSSTableMultiWriter. getTableId()
TableId
SSTableMultiWriter. getTableId()
Constructor parameters in org.apache.cassandra.io.sstable with type arguments of type TableId Constructor Description IndexSummaryRedistribution(java.util.Map<TableId,LifecycleTransaction> transactions, long nonRedistributingOffHeapSize, long memoryPoolBytes)
-
Uses of TableId in org.apache.cassandra.io.sstable.format
Methods in org.apache.cassandra.io.sstable.format that return TableId Modifier and Type Method Description TableId
RangeAwareSSTableWriter. getTableId()
-
Uses of TableId in org.apache.cassandra.io.sstable.format.big
Methods in org.apache.cassandra.io.sstable.format.big that return TableId Modifier and Type Method Description TableId
BigTableZeroCopyWriter. getTableId()
-
Uses of TableId in org.apache.cassandra.repair.consistent
Fields in org.apache.cassandra.repair.consistent with type parameters of type TableId Modifier and Type Field Description com.google.common.collect.ImmutableSet<TableId>
ConsistentSession. tableIds
Methods in org.apache.cassandra.repair.consistent with parameters of type TableId Modifier and Type Method Description CleanupSummary
LocalSessions. cleanup(TableId tid, java.util.Collection<Range<Token>> ranges, boolean force)
PendingStats
LocalSessions. getPendingStats(TableId tid, java.util.Collection<Range<Token>> ranges)
RepairedState.Stats
LocalSessions. getRepairedStats(TableId tid, java.util.Collection<Range<Token>> ranges)
-
Uses of TableId in org.apache.cassandra.repair.messages
Fields in org.apache.cassandra.repair.messages with type parameters of type TableId Modifier and Type Field Description java.util.List<TableId>
PrepareMessage. tableIds
Constructor parameters in org.apache.cassandra.repair.messages with type arguments of type TableId Constructor Description PrepareMessage(java.util.UUID parentRepairSession, java.util.List<TableId> tableIds, java.util.Collection<Range<Token>> ranges, boolean isIncremental, long timestamp, boolean isGlobal, PreviewKind previewKind)
-
Uses of TableId in org.apache.cassandra.schema
Fields in org.apache.cassandra.schema declared as TableId Modifier and Type Field Description TableId
ViewMetadata. baseTableId
TableId
TableMetadata. id
TableId
TableMetadataRef. id
Methods in org.apache.cassandra.schema that return TableId Modifier and Type Method Description static TableId
TableId. deserialize(java.io.DataInput in)
static TableId
TableId. forSystemTable(java.lang.String keyspace, java.lang.String table)
Creates the UUID of a system table.static TableId
TableId. fromString(java.lang.String idString)
static TableId
TableId. fromUUID(java.util.UUID id)
static TableId
TableId. generate()
Methods in org.apache.cassandra.schema with parameters of type TableId Modifier and Type Method Description static TableMetadata.Builder
TableMetadata. builder(java.lang.String keyspace, java.lang.String table, TableId id)
java.lang.Iterable<ViewMetadata>
Views. forTable(TableId tableId)
ColumnFamilyStore
Schema. getColumnFamilyStoreInstance(TableId id)
default TableMetadata
SchemaProvider. getExistingTableMetadata(TableId id)
TableMetadata
Schema. getTableMetadata(TableId id)
TableMetadata
SchemaProvider. getTableMetadata(TableId id)
TableMetadataRef
Schema. getTableMetadataRef(TableId id)
Get Table metadata by its identifierTableMetadataRef
SchemaProvider. getTableMetadataRef(TableId id)
TableMetadata
Keyspaces. getTableOrViewNullable(TableId id)
TableMetadata.Builder
TableMetadata.Builder. id(TableId val)
java.util.stream.Stream<ViewMetadata>
Views. stream(TableId tableId)
Constructors in org.apache.cassandra.schema with parameters of type TableId Constructor Description ViewMetadata(TableId baseTableId, java.lang.String baseTableName, boolean includeAllColumns, WhereClause whereClause, TableMetadata metadata)
-
Uses of TableId in org.apache.cassandra.service
Methods in org.apache.cassandra.service that return types with arguments of type TableId Modifier and Type Method Description java.util.Set<TableId>
ActiveRepairService.ParentRepairSession. getTableIds()
-
Uses of TableId in org.apache.cassandra.streaming
Fields in org.apache.cassandra.streaming declared as TableId Modifier and Type Field Description TableId
StreamSummary. tableId
protected TableId
StreamTask. tableId
Fields in org.apache.cassandra.streaming with type parameters of type TableId Modifier and Type Field Description protected java.util.concurrent.ConcurrentHashMap<TableId,StreamTransferTask>
StreamSession. transfers
Methods in org.apache.cassandra.streaming that return TableId Modifier and Type Method Description TableId
IncomingStream. getTableId()
TableId
OutgoingStream. getTableId()
Methods in org.apache.cassandra.streaming with parameters of type TableId Modifier and Type Method Description StreamReceiver
StreamSession. getAggregator(TableId tableId)
void
StreamSession. received(TableId tableId, int sequenceNumber)
void
StreamHook. reportIncomingStream(TableId tableId, IncomingStream stream, StreamSession session, int sequenceNumber)
Constructors in org.apache.cassandra.streaming with parameters of type TableId Constructor Description StreamReceiveTask(StreamSession session, TableId tableId, int totalStreams, long totalSize)
StreamSummary(TableId tableId, int files, long totalSize)
StreamTask(StreamSession session, TableId tableId)
StreamTransferTask(StreamSession session, TableId tableId)
-
Uses of TableId in org.apache.cassandra.streaming.messages
Fields in org.apache.cassandra.streaming.messages declared as TableId Modifier and Type Field Description TableId
ReceivedMessage. tableId
TableId
StreamMessageHeader. tableId
Constructors in org.apache.cassandra.streaming.messages with parameters of type TableId Constructor Description OutgoingStreamMessage(TableId tableId, StreamSession session, OutgoingStream stream, int sequenceNumber)
ReceivedMessage(TableId tableId, int sequenceNumber)
StreamMessageHeader(TableId tableId, InetAddressAndPort sender, java.util.UUID planId, boolean sendByFollower, int sessionIndex, int sequenceNumber, long repairedAt, java.util.UUID pendingRepair)
-