Package | Description |
---|---|
org.apache.cassandra.db | |
org.apache.cassandra.db.commitlog | |
org.apache.cassandra.db.lifecycle | |
org.apache.cassandra.db.view | |
org.apache.cassandra.io.sstable.metadata |
Modifier and Type | Class and Description |
---|---|
static class |
Memtable.LastReplayPosition |
Modifier and Type | Method and Description |
---|---|
ReplayPosition |
ColumnFamilyStore.forceBlockingFlush() |
ReplayPosition |
Memtable.getCommitLogLowerBound() |
ReplayPosition |
Memtable.getCommitLogUpperBound() |
static ReplayPosition |
SystemKeyspace.getTruncatedPosition(java.util.UUID cfId) |
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<ReplayPosition> |
ColumnFamilyStore.dumpMemtable()
Drops current memtable without flushing to disk.
|
com.google.common.util.concurrent.ListenableFuture<ReplayPosition> |
ColumnFamilyStore.forceFlush()
Flush if there is unflushed data in the memtables
|
com.google.common.util.concurrent.ListenableFuture<ReplayPosition> |
ColumnFamilyStore.forceFlush(ReplayPosition flushIfDirtyBefore)
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
|
com.google.common.util.concurrent.ListenableFuture<ReplayPosition> |
ColumnFamilyStore.switchMemtable() |
com.google.common.util.concurrent.ListenableFuture<ReplayPosition> |
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,
ReplayPosition replayPosition) |
void |
ColumnFamilyStore.apply(PartitionUpdate update,
UpdateTransaction indexer,
OpOrder.Group opGroup,
ReplayPosition replayPosition)
Insert/Update the column family for this key.
|
com.google.common.util.concurrent.ListenableFuture<ReplayPosition> |
ColumnFamilyStore.forceFlush(ReplayPosition flushIfDirtyBefore)
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
|
boolean |
Memtable.mayContainDataBefore(ReplayPosition position) |
static void |
SystemKeyspace.saveTruncationRecord(ColumnFamilyStore cfs,
long truncatedAt,
ReplayPosition position) |
Modifier and Type | Method and Description |
---|---|
void |
Memtable.setDiscarding(OpOrder.Barrier writeBarrier,
java.util.concurrent.atomic.AtomicReference<ReplayPosition> lastReplayPosition) |
Constructor and Description |
---|
LastReplayPosition(ReplayPosition copy) |
Constructor and Description |
---|
Memtable(java.util.concurrent.atomic.AtomicReference<ReplayPosition> commitLogLowerBound,
ColumnFamilyStore cfs) |
Modifier and Type | Field and Description |
---|---|
static ReplayPosition |
ReplayPosition.NONE |
Modifier and Type | Method and Description |
---|---|
ReplayPosition |
CommitLog.add(Mutation mutation)
Add a Mutation to the commit log.
|
ReplayPosition |
ReplayPosition.clone() |
ReplayPosition |
ReplayPosition.ReplayPositionSerializer.deserialize(DataInputPlus in) |
static ReplayPosition |
CommitLogReplayer.firstNotCovered(java.util.Collection<IntervalSet<ReplayPosition>> ranges)
Find the earliest commit log position that is not covered by the known flushed ranges for some table.
|
ReplayPosition |
CommitLog.getContext() |
ReplayPosition |
CommitLogSegment.getContext() |
Modifier and Type | Method and Description |
---|---|
static IntervalSet<ReplayPosition> |
CommitLogReplayer.persistedIntervals(java.lang.Iterable<SSTableReader> onDisk,
ReplayPosition truncatedAt)
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 |
ReplayPosition.compareTo(ReplayPosition that) |
boolean |
CommitLogSegment.contains(ReplayPosition context)
Check to see if a certain ReplayPosition is contained by this segment file.
|
void |
CommitLog.discardCompletedSegments(java.util.UUID cfId,
ReplayPosition lowerBound,
ReplayPosition upperBound)
Modifies the per-CF dirty cursors of any commit log segments for the column family according to the position
given.
|
void |
CommitLogSegment.markClean(java.util.UUID cfId,
ReplayPosition startPosition,
ReplayPosition endPosition)
Marks the ColumnFamily specified by cfId as clean for this log segment.
|
static IntervalSet<ReplayPosition> |
CommitLogReplayer.persistedIntervals(java.lang.Iterable<SSTableReader> onDisk,
ReplayPosition truncatedAt)
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 |
ReplayPosition.ReplayPositionSerializer.serialize(ReplayPosition rp,
DataOutputPlus out) |
long |
ReplayPosition.ReplayPositionSerializer.serializedSize(ReplayPosition rp) |
Modifier and Type | Method and Description |
---|---|
static ReplayPosition |
CommitLogReplayer.firstNotCovered(java.util.Collection<IntervalSet<ReplayPosition>> 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,
ReplayPosition replayPosition)
get the Memtable that the ordered writeOp should be directed to
|
Modifier and Type | Method and Description |
---|---|
void |
TableViews.truncateBlocking(ReplayPosition replayAfter,
long truncatedAt) |
Modifier and Type | Field and Description |
---|---|
IntervalSet<ReplayPosition> |
StatsMetadata.commitLogIntervals |
static ISerializer<IntervalSet<ReplayPosition>> |
StatsMetadata.replayPositionSetSerializer |
Constructor and Description |
---|
StatsMetadata(EstimatedHistogram estimatedPartitionSize,
EstimatedHistogram estimatedColumnCount,
IntervalSet<ReplayPosition> commitLogIntervals,
long minTimestamp,
long maxTimestamp,
int minLocalDeletionTime,
int maxLocalDeletionTime,
int minTTL,
int maxTTL,
double compressionRatio,
StreamingHistogram 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) |
Copyright © 2017 The Apache Software Foundation