Modifier and Type | Field and Description |
---|---|
TableId |
CacheKey.tableId |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
TableId |
TableAttributes.getId() |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<TableId> |
CounterMutation.getTableIds() |
java.util.Collection<TableId> |
IMutation.getTableIds() |
java.util.Collection<TableId> |
Mutation.getTableIds() |
Modifier and Type | Method and 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 family
|
void |
StorageHook.reportRead(TableId tableId,
DecoratedKey key) |
void |
StorageHook.reportWrite(TableId tableId,
PartitionUpdate partitionUpdate) |
Mutation |
Mutation.without(TableId tableId) |
Modifier and Type | Method and Description |
---|---|
Mutation |
Mutation.without(java.util.Set<TableId> tableIds) |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<TableId> |
CommitLogSegment.getDirtyTableIds() |
java.util.Set<java.util.Map.Entry<TableId,java.util.concurrent.atomic.AtomicInteger>> |
CommitLogReader.getInvalidMutations() |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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
|
Modifier and Type | Field and Description |
---|---|
TableId |
CassandraStreamHeader.tableId |
protected TableId |
CassandraStreamReader.tableId |
Modifier and Type | Method and Description |
---|---|
TableId |
CassandraIncomingFile.getTableId() |
TableId |
CassandraOutgoingFile.getTableId() |
Modifier and Type | Method and Description |
---|---|
CassandraStreamHeader.Builder |
CassandraStreamHeader.Builder.withTableId(TableId tableId) |
Modifier and Type | Method and Description |
---|---|
CassandraStreamHeader |
CassandraStreamHeader.CassandraStreamHeaderSerializer.deserialize(DataInputPlus in,
int version,
java.util.function.Function<TableId,IPartitioner> partitionerMapper) |
Modifier and Type | Method and Description |
---|---|
TableViews |
ViewManager.forTable(TableId id) |
Constructor and Description |
---|
TableViews(TableId id) |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<TableId> |
VirtualMutation.getTableIds() |
Modifier and Type | Method and Description |
---|---|
TableMetadata |
VirtualKeyspaceRegistry.getTableMetadataNullable(TableId id) |
VirtualTable |
VirtualKeyspaceRegistry.getTableNullable(TableId id) |
Constructor and Description |
---|
VirtualMutation(java.lang.String keyspaceName,
DecoratedKey partitionKey,
com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications) |
Modifier and Type | Field and Description |
---|---|
TableId |
UnknownTableException.id |
Constructor and Description |
---|
UnknownTableException(java.lang.String msg,
TableId id) |
Modifier and Type | Method and Description |
---|---|
TableId |
SSTableMultiWriter.getTableId() |
TableId |
SimpleSSTableMultiWriter.getTableId() |
Constructor and Description |
---|
IndexSummaryRedistribution(java.util.Map<TableId,LifecycleTransaction> transactions,
long nonRedistributingOffHeapSize,
long memoryPoolBytes) |
Modifier and Type | Method and Description |
---|---|
TableId |
RangeAwareSSTableWriter.getTableId() |
Modifier and Type | Method and Description |
---|---|
TableId |
BigTableZeroCopyWriter.getTableId() |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.ImmutableSet<TableId> |
ConsistentSession.tableIds |
Modifier and Type | Method and 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) |
Modifier and Type | Field and Description |
---|---|
java.util.List<TableId> |
PrepareMessage.tableIds |
Constructor and 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) |
Modifier and Type | Field and Description |
---|---|
TableId |
ViewMetadata.baseTableId |
TableId |
TableMetadata.id |
TableId |
TableMetadataRef.id |
Modifier and Type | Method and 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() |
Modifier and Type | Method and 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 identifier
|
TableMetadataRef |
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) |
Constructor and Description |
---|
ViewMetadata(TableId baseTableId,
java.lang.String baseTableName,
boolean includeAllColumns,
WhereClause whereClause,
TableMetadata metadata) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<TableId> |
ActiveRepairService.ParentRepairSession.getTableIds() |
Modifier and Type | Field and Description |
---|---|
TableId |
StreamSummary.tableId |
protected TableId |
StreamTask.tableId |
Modifier and Type | Field and Description |
---|---|
protected java.util.concurrent.ConcurrentHashMap<TableId,StreamTransferTask> |
StreamSession.transfers |
Modifier and Type | Method and Description |
---|---|
TableId |
IncomingStream.getTableId() |
TableId |
OutgoingStream.getTableId() |
Modifier and Type | Method and Description |
---|---|
StreamReceiver |
StreamSession.getAggregator(TableId tableId) |
void |
StreamSession.received(TableId tableId,
int sequenceNumber) |
void |
StreamHook.reportIncomingStream(TableId tableId,
IncomingStream stream,
StreamSession session,
int sequenceNumber) |
Constructor and 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) |
Modifier and Type | Field and Description |
---|---|
TableId |
ReceivedMessage.tableId |
TableId |
StreamMessageHeader.tableId |
Constructor and 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) |
Copyright © 2009-2022 The Apache Software Foundation