Modifier and Type | Class and Description |
---|---|
static class |
Memtable.LastCommitLogPosition |
Modifier and Type | Method and Description |
---|---|
CommitLogPosition |
ColumnFamilyStore.forceBlockingFlush() |
CommitLogPosition |
Memtable.getCommitLogLowerBound() |
CommitLogPosition |
Memtable.getCommitLogUpperBound() |
CommitLogPosition |
CassandraWriteContext.getPosition() |
static CommitLogPosition |
SystemKeyspace.getTruncatedPosition(TableId id) |
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<CommitLogPosition> |
ColumnFamilyStore.dumpMemtable()
Drops current memtable without flushing to disk.
|
com.google.common.util.concurrent.ListenableFuture<CommitLogPosition> |
ColumnFamilyStore.forceFlush()
Flush if there is unflushed data in the memtables
|
com.google.common.util.concurrent.ListenableFuture<CommitLogPosition> |
ColumnFamilyStore.switchMemtable() |
com.google.common.util.concurrent.ListenableFuture<CommitLogPosition> |
ColumnFamilyStore.switchMemtableIfCurrent(Memtable memtable)
Switches the memtable iff the live memtable is the one provided
|
Modifier and Type | Method and Description |
---|---|
boolean |
Memtable.accepts(OpOrder.Group opGroup,
CommitLogPosition commitLogPosition) |
void |
ColumnFamilyStore.apply(PartitionUpdate update,
UpdateTransaction indexer,
OpOrder.Group opGroup,
CommitLogPosition commitLogPosition)
Insert/Update the column family for this key.
|
com.google.common.util.concurrent.ListenableFuture<?> |
ColumnFamilyStore.forceFlush(CommitLogPosition flushIfDirtyBefore)
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
|
boolean |
Memtable.mayContainDataBefore(CommitLogPosition position) |
static void |
SystemKeyspace.saveTruncationRecord(ColumnFamilyStore cfs,
long truncatedAt,
CommitLogPosition position) |
Modifier and Type | Method and Description |
---|---|
void |
Memtable.setDiscarding(OpOrder.Barrier writeBarrier,
java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound) |
Constructor and Description |
---|
CassandraWriteContext(OpOrder.Group opGroup,
CommitLogPosition position) |
LastCommitLogPosition(CommitLogPosition copy) |
Constructor and Description |
---|
Memtable(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound,
ColumnFamilyStore cfs) |
Modifier and Type | Field and Description |
---|---|
static CommitLogPosition |
CommitLogPosition.NONE |
Modifier and Type | Field and Description |
---|---|
static java.util.Comparator<CommitLogPosition> |
CommitLogPosition.comparator |
Modifier and Type | Method and Description |
---|---|
CommitLogPosition |
CommitLog.add(Mutation mutation)
Add a Mutation to the commit log.
|
CommitLogPosition |
CommitLogPosition.clone() |
CommitLogPosition |
CommitLogPosition.CommitLogPositionSerializer.deserialize(DataInputPlus in) |
static CommitLogPosition |
CommitLogReplayer.firstNotCovered(java.util.Collection<IntervalSet<CommitLogPosition>> ranges)
Find the earliest commit log position that is not covered by the known flushed ranges for some table.
|
CommitLogPosition |
CommitLogSegment.Allocation.getCommitLogPosition()
Returns the position in the CommitLogSegment at the end of this allocation.
|
CommitLogPosition |
CommitLogSegment.getCurrentCommitLogPosition() |
CommitLogPosition |
CommitLog.getCurrentPosition() |
Modifier and Type | Method and Description |
---|---|
static IntervalSet<CommitLogPosition> |
CommitLogReplayer.persistedIntervals(java.lang.Iterable<SSTableReader> onDisk,
CommitLogPosition truncatedAt,
java.util.UUID localhostId)
A set of known safe-to-discard commit log replay positions, based on
the range covered by on disk sstables and those prior to the most recent truncation record
|
Modifier and Type | Method and Description |
---|---|
int |
CommitLogPosition.compareTo(CommitLogPosition other) |
boolean |
CommitLogSegment.contains(CommitLogPosition context)
Check to see if a certain CommitLogPosition is contained by this segment file.
|
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.
|
static IntervalSet<CommitLogPosition> |
CommitLogReplayer.persistedIntervals(java.lang.Iterable<SSTableReader> onDisk,
CommitLogPosition truncatedAt,
java.util.UUID localhostId)
A set of known safe-to-discard commit log replay positions, based on
the range covered by on disk sstables and those prior to the most recent truncation record
|
void |
CommitLogReader.readAllFiles(CommitLogReadHandler handler,
java.io.File[] files,
CommitLogPosition minPosition)
Reads all passed in files with minPosition, no start, and no mutation limit.
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
java.io.File file,
CommitLogPosition minPosition,
boolean tolerateTruncation)
Reads all mutations from passed in file from minPosition
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
java.io.File file,
CommitLogPosition minPosition,
int mutationLimit,
boolean tolerateTruncation)
Reads mutations from file, handing them off to handler
|
protected void |
CommitLogReader.readMutation(CommitLogReadHandler handler,
byte[] inputBuffer,
int size,
CommitLogPosition minPosition,
int entryLocation,
CommitLogDescriptor desc)
Deserializes and passes a Mutation to the ICommitLogReadHandler requested
|
void |
CommitLogPosition.CommitLogPositionSerializer.serialize(CommitLogPosition clsp,
DataOutputPlus out) |
long |
CommitLogPosition.CommitLogPositionSerializer.serializedSize(CommitLogPosition clsp) |
Modifier and Type | Method and Description |
---|---|
static CommitLogPosition |
CommitLogReplayer.firstNotCovered(java.util.Collection<IntervalSet<CommitLogPosition>> ranges)
Find the earliest commit log position that is not covered by the known flushed ranges for some table.
|
Modifier and Type | Method and Description |
---|---|
Memtable |
Tracker.getMemtableFor(OpOrder.Group opGroup,
CommitLogPosition commitLogPosition)
get the Memtable that the ordered writeOp should be directed to
|
Modifier and Type | Method and Description |
---|---|
void |
TableViews.truncateBlocking(CommitLogPosition replayAfter,
long truncatedAt) |
Modifier and Type | Field and Description |
---|---|
protected IntervalSet<CommitLogPosition> |
MetadataCollector.commitLogIntervals |
IntervalSet<CommitLogPosition> |
StatsMetadata.commitLogIntervals |
static ISerializer<IntervalSet<CommitLogPosition>> |
StatsMetadata.commitLogPositionSetSerializer |
Modifier and Type | Method and Description |
---|---|
MetadataCollector |
MetadataCollector.commitLogIntervals(IntervalSet<CommitLogPosition> commitLogIntervals) |
Constructor and Description |
---|
StatsMetadata(EstimatedHistogram estimatedPartitionSize,
EstimatedHistogram estimatedCellPerPartitionCount,
IntervalSet<CommitLogPosition> commitLogIntervals,
long minTimestamp,
long maxTimestamp,
int minLocalDeletionTime,
int maxLocalDeletionTime,
int minTTL,
int maxTTL,
double compressionRatio,
TombstoneHistogram estimatedTombstoneDropTime,
int sstableLevel,
java.util.List<java.nio.ByteBuffer> minClusteringValues,
java.util.List<java.nio.ByteBuffer> maxClusteringValues,
boolean hasLegacyCounterShards,
long repairedAt,
long totalColumnsSet,
long totalRows,
java.util.UUID originatingHostId,
java.util.UUID pendingRepair,
boolean isTransient) |
Copyright © 2009-2022 The Apache Software Foundation