Modifier and Type | Method and Description |
---|---|
CommitLogPosition |
ColumnFamilyStore.forceBlockingFlush(ColumnFamilyStore.FlushReason reason) |
CommitLogPosition |
CassandraWriteContext.getPosition() |
static CommitLogPosition |
SystemKeyspace.getTruncatedPosition(TableId id) |
Modifier and Type | Method and Description |
---|---|
Future<CommitLogPosition> |
ColumnFamilyStore.dumpMemtable()
Drops current memtable without flushing to disk.
|
Future<CommitLogPosition> |
ColumnFamilyStore.forceFlush(ColumnFamilyStore.FlushReason reason)
Flush if there is unflushed data in the memtables
|
Future<CommitLogPosition> |
ColumnFamilyStore.signalFlushRequired(Memtable memtable,
ColumnFamilyStore.FlushReason reason) |
Future<CommitLogPosition> |
ColumnFamilyStore.switchMemtable(ColumnFamilyStore.FlushReason reason) |
Future<CommitLogPosition> |
ColumnFamilyStore.switchMemtableIfCurrent(Memtable memtable,
ColumnFamilyStore.FlushReason reason)
Switches the memtable iff the live memtable is the one provided
|
Modifier and Type | Method and Description |
---|---|
void |
ColumnFamilyStore.apply(PartitionUpdate update,
UpdateTransaction indexer,
OpOrder.Group opGroup,
CommitLogPosition commitLogPosition)
Insert/Update the column family for this key.
|
Future<?> |
ColumnFamilyStore.forceFlush(CommitLogPosition flushIfDirtyBefore)
Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore
(inclusive).
|
static void |
SystemKeyspace.saveTruncationRecord(ColumnFamilyStore cfs,
long truncatedAt,
CommitLogPosition position) |
Modifier and Type | Method and Description |
---|---|
Memtable |
ColumnFamilyStore.createMemtable(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound) |
Constructor and Description |
---|
CassandraWriteContext(OpOrder.Group opGroup,
CommitLogPosition position) |
Modifier and Type | Field and Description |
---|---|
static CommitLogPosition |
CommitLogPosition.NONE |
CommitLogPosition |
CommitLogArchiver.snapshotCommitLogPosition |
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 |
CommitLogPosition.CommitLogPositionSerializer.fromString(java.lang.String position) |
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,
File[] files,
CommitLogPosition minPosition)
Reads all passed in files with minPosition, no start, and no mutation limit.
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
File file,
CommitLogPosition minPosition,
boolean tolerateTruncation)
Reads all mutations from passed in file from minPosition
|
void |
CommitLogReader.readCommitLogSegment(CommitLogReadHandler handler,
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) |
java.lang.String |
CommitLogPosition.CommitLogPositionSerializer.toString(CommitLogPosition position) |
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.
|
Constructor and Description |
---|
CommitLogArchiver(java.lang.String archiveCommand,
java.lang.String restoreCommand,
java.lang.String restoreDirectories,
long restorePointInTime,
CommitLogPosition snapshotCommitLogPosition,
java.util.concurrent.TimeUnit precision) |
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 | Class and Description |
---|---|
static class |
Memtable.LastCommitLogPosition
Special commit log position marker used in the upper bound marker setting process
(see
ColumnFamilyStore.setCommitLogUpperBound(java.util.concurrent.atomic.AtomicReference<org.apache.cassandra.db.commitlog.CommitLogPosition>) and Memtable.accepts(org.apache.cassandra.utils.concurrent.OpOrder.Group, org.apache.cassandra.db.commitlog.CommitLogPosition) ) |
Modifier and Type | Method and Description |
---|---|
CommitLogPosition |
AbstractMemtable.AbstractFlushablePartitionSet.commitLogLowerBound() |
CommitLogPosition |
Memtable.FlushablePartitionSet.commitLogLowerBound()
The commit log position at the time that this memtable was created
|
CommitLogPosition |
Memtable.FlushablePartitionSet.commitLogUpperBound()
The commit log position at the time that this memtable was switched out
|
CommitLogPosition |
AbstractMemtableWithCommitlog.getApproximateCommitLogLowerBound() |
CommitLogPosition |
Memtable.getApproximateCommitLogLowerBound()
Approximate commit log lower bound, <= getCommitLogLowerBound, used as a time stamp for ordering
|
CommitLogPosition |
AbstractMemtableWithCommitlog.getCommitLogLowerBound() |
CommitLogPosition |
Memtable.getCommitLogLowerBound()
The commit log position at the time that this memtable was created
|
Modifier and Type | Method and Description |
---|---|
Future<CommitLogPosition> |
Memtable.Owner.signalFlushRequired(Memtable memtable,
ColumnFamilyStore.FlushReason reason)
Signal to the owner that a flush is required (e.g.
|
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractMemtableWithCommitlog.accepts(OpOrder.Group opGroup,
CommitLogPosition commitLogPosition) |
boolean |
Memtable.accepts(OpOrder.Group opGroup,
CommitLogPosition commitLogPosition)
Decide if this memtable should take a write with the given parameters, or if the write should go to the next
memtable.
|
boolean |
AbstractMemtableWithCommitlog.mayContainDataBefore(CommitLogPosition position) |
boolean |
Memtable.mayContainDataBefore(CommitLogPosition position)
True if the memtable can contain any data that was written before the given commit log position
|
Modifier and Type | Method and Description |
---|---|
Memtable |
Memtable.Factory.create(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound,
TableMetadataRef metadaRef,
Memtable.Owner owner)
Create a memtable.
|
Memtable |
SkipListMemtableFactory.create(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound,
TableMetadataRef metadaRef,
Memtable.Owner owner) |
void |
AbstractAllocatorMemtable.switchOut(OpOrder.Barrier writeBarrier,
java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound) |
void |
AbstractMemtableWithCommitlog.switchOut(OpOrder.Barrier writeBarrier,
java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound) |
void |
Memtable.switchOut(OpOrder.Barrier writeBarrier,
java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound)
Called to tell the memtable that it is being switched out and will be flushed (or dropped) and discarded.
|
Constructor and Description |
---|
LastCommitLogPosition(CommitLogPosition copy) |
Constructor and Description |
---|
AbstractAllocatorMemtable(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound,
TableMetadataRef metadataRef,
Memtable.Owner owner) |
AbstractMemtableWithCommitlog(TableMetadataRef metadataRef,
java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound) |
SkipListMemtable(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound,
TableMetadataRef metadataRef,
Memtable.Owner owner) |
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,
TimeUUID pendingRepair,
boolean isTransient) |
Copyright © 2009- The Apache Software Foundation