Uses of Class
org.apache.cassandra.db.commitlog.CommitLogPosition
-
-
Uses of CommitLogPosition in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return CommitLogPosition Modifier and Type Method Description CommitLogPositionColumnFamilyStore. forceBlockingFlush(ColumnFamilyStore.FlushReason reason)CommitLogPositionCassandraWriteContext. getPosition()static CommitLogPositionSystemKeyspace. getTruncatedPosition(TableId id)Methods in org.apache.cassandra.db that return types with arguments of type CommitLogPosition Modifier and Type Method 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 memtablesFuture<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 providedMethods in org.apache.cassandra.db with parameters of type CommitLogPosition Modifier and Type Method Description Future<?>ColumnFamilyStore. forceFlush(CommitLogPosition flushIfDirtyBefore)Flush if there is unflushed data that was written to the CommitLog before @param flushIfDirtyBefore (inclusive).static voidSystemKeyspace. saveTruncationRecord(ColumnFamilyStore cfs, long truncatedAt, CommitLogPosition position)Method parameters in org.apache.cassandra.db with type arguments of type CommitLogPosition Modifier and Type Method Description MemtableColumnFamilyStore. createMemtable(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound)SSTableMultiWriterColumnFamilyStore. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, LifecycleNewTracker lifecycleNewTracker)SSTableMultiWriterColumnFamilyStore. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, SerializationHeader header, LifecycleNewTracker lifecycleNewTracker)Constructors in org.apache.cassandra.db with parameters of type CommitLogPosition Constructor Description CassandraWriteContext(OpOrder.Group opGroup, CommitLogPosition position) -
Uses of CommitLogPosition in org.apache.cassandra.db.commitlog
Fields in org.apache.cassandra.db.commitlog declared as CommitLogPosition Modifier and Type Field Description static CommitLogPositionCommitLogPosition. NONEFields in org.apache.cassandra.db.commitlog with type parameters of type CommitLogPosition Modifier and Type Field Description static java.util.Comparator<CommitLogPosition>CommitLogPosition. comparatorMethods in org.apache.cassandra.db.commitlog that return CommitLogPosition Modifier and Type Method Description CommitLogPositionCommitLog. add(Mutation mutation)Add a Mutation to the commit log.CommitLogPositionCommitLogPosition. clone()CommitLogPositionCommitLogPosition.CommitLogPositionSerializer. deserialize(DataInputPlus in)static CommitLogPositionCommitLogReplayer. 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.CommitLogPositionCommitLogPosition.CommitLogPositionSerializer. fromString(java.lang.String position)CommitLogPositionCommitLogSegment.Allocation. getCommitLogPosition()Returns the position in the CommitLogSegment at the end of this allocation.CommitLogPositionCommitLogSegment. getCurrentCommitLogPosition()CommitLogPositionCommitLog. getCurrentPosition()Methods in org.apache.cassandra.db.commitlog that return types with arguments of type CommitLogPosition Modifier and Type Method 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 recordMethods in org.apache.cassandra.db.commitlog with parameters of type CommitLogPosition Modifier and Type Method Description intCommitLogPosition. compareTo(CommitLogPosition other)booleanCommitLogSegment. contains(CommitLogPosition context)Check to see if a certain CommitLogPosition is contained by this segment file.voidCommitLog. 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.voidCommitLogSegment. 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 recordvoidCommitLogReader. readAllFiles(CommitLogReadHandler handler, File[] files, CommitLogPosition minPosition)Reads all passed in files with minPosition, no start, and no mutation limit.voidCommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, CommitLogPosition minPosition, boolean tolerateTruncation)Reads all mutations from passed in file from minPositionvoidCommitLogReader. readCommitLogSegment(CommitLogReadHandler handler, File file, CommitLogPosition minPosition, int mutationLimit, boolean tolerateTruncation)Reads mutations from file, handing them off to handlerprotected voidCommitLogReader. readMutation(CommitLogReadHandler handler, byte[] inputBuffer, int size, CommitLogPosition minPosition, int entryLocation, CommitLogDescriptor desc)Deserializes and passes a Mutation to the ICommitLogReadHandler requestedvoidCommitLogPosition.CommitLogPositionSerializer. serialize(CommitLogPosition clsp, DataOutputPlus out)longCommitLogPosition.CommitLogPositionSerializer. serializedSize(CommitLogPosition clsp)java.lang.StringCommitLogPosition.CommitLogPositionSerializer. toString(CommitLogPosition position)Method parameters in org.apache.cassandra.db.commitlog with type arguments of type CommitLogPosition Modifier and Type Method Description static CommitLogPositionCommitLogReplayer. 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.Constructors in org.apache.cassandra.db.commitlog with parameters of type CommitLogPosition Constructor Description CommitLogArchiver(java.lang.String archiveCommand, java.lang.String restoreCommand, java.lang.String restoreDirectories, long restorePointInTimeInMicroseconds, CommitLogPosition snapshotCommitLogPosition, java.util.concurrent.TimeUnit precision) -
Uses of CommitLogPosition in org.apache.cassandra.db.compaction
Method parameters in org.apache.cassandra.db.compaction with type arguments of type CommitLogPosition Modifier and Type Method Description SSTableMultiWriterAbstractCompactionStrategy. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)abstract SSTableMultiWriterAbstractStrategyHolder. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)SSTableMultiWriterCompactionStrategyHolder. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)SSTableMultiWriterCompactionStrategyManager. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)SSTableMultiWriterPendingRepairHolder. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)SSTableMultiWriterUnifiedCompactionStrategy. createSSTableMultiWriter(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker)Create the sstable writer used for flushing. -
Uses of CommitLogPosition in org.apache.cassandra.db.compaction.unified
Constructor parameters in org.apache.cassandra.db.compaction.unified with type arguments of type CommitLogPosition Constructor Description ShardedMultiWriter(ColumnFamilyStore cfs, Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, IntervalSet<CommitLogPosition> commitLogPositions, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker, ShardTracker boundaries) -
Uses of CommitLogPosition in org.apache.cassandra.db.lifecycle
Methods in org.apache.cassandra.db.lifecycle with parameters of type CommitLogPosition Modifier and Type Method Description MemtableTracker. getMemtableFor(OpOrder.Group opGroup, CommitLogPosition commitLogPosition)get the Memtable that the ordered writeOp should be directed to -
Uses of CommitLogPosition in org.apache.cassandra.db.memtable
Subclasses of CommitLogPosition in org.apache.cassandra.db.memtable Modifier and Type Class Description static classMemtable.LastCommitLogPositionSpecial commit log position marker used in the upper bound marker setting process (seeColumnFamilyStore.setCommitLogUpperBound(java.util.concurrent.atomic.AtomicReference<org.apache.cassandra.db.commitlog.CommitLogPosition>)andMemtable.accepts(org.apache.cassandra.utils.concurrent.OpOrder.Group, org.apache.cassandra.db.commitlog.CommitLogPosition))Methods in org.apache.cassandra.db.memtable that return CommitLogPosition Modifier and Type Method Description CommitLogPositionAbstractMemtable.AbstractFlushablePartitionSet. commitLogLowerBound()CommitLogPositionMemtable.FlushablePartitionSet. commitLogLowerBound()The commit log position at the time that this memtable was createdCommitLogPositionMemtable.FlushablePartitionSet. commitLogUpperBound()The commit log position at the time that this memtable was switched outCommitLogPositionAbstractMemtableWithCommitlog. getApproximateCommitLogLowerBound()CommitLogPositionMemtable. getApproximateCommitLogLowerBound()Approximate commit log lower bound, <= getCommitLogLowerBound, used as a time stamp for orderingCommitLogPositionAbstractMemtableWithCommitlog. getCommitLogLowerBound()CommitLogPositionMemtable. getCommitLogLowerBound()The commit log position at the time that this memtable was createdMethods in org.apache.cassandra.db.memtable that return types with arguments of type CommitLogPosition Modifier and Type Method Description Future<CommitLogPosition>Memtable.Owner. signalFlushRequired(Memtable memtable, ColumnFamilyStore.FlushReason reason)Signal to the owner that a flush is required (e.g.Methods in org.apache.cassandra.db.memtable with parameters of type CommitLogPosition Modifier and Type Method Description booleanAbstractMemtableWithCommitlog. accepts(OpOrder.Group opGroup, CommitLogPosition commitLogPosition)booleanMemtable. 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.booleanAbstractMemtableWithCommitlog. mayContainDataBefore(CommitLogPosition position)booleanMemtable. mayContainDataBefore(CommitLogPosition position)True if the memtable can contain any data that was written before the given commit log positionMethod parameters in org.apache.cassandra.db.memtable with type arguments of type CommitLogPosition Modifier and Type Method Description MemtableMemtable.Factory. create(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound, TableMetadataRef metadaRef, Memtable.Owner owner)Create a memtable.MemtableSkipListMemtableFactory. create(java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogLowerBound, TableMetadataRef metadaRef, Memtable.Owner owner)voidAbstractAllocatorMemtable. switchOut(OpOrder.Barrier writeBarrier, java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound)voidAbstractMemtableWithCommitlog. switchOut(OpOrder.Barrier writeBarrier, java.util.concurrent.atomic.AtomicReference<CommitLogPosition> commitLogUpperBound)voidMemtable. 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.Constructors in org.apache.cassandra.db.memtable with parameters of type CommitLogPosition Constructor Description LastCommitLogPosition(CommitLogPosition copy)Constructor parameters in org.apache.cassandra.db.memtable with type arguments of type CommitLogPosition Constructor 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) -
Uses of CommitLogPosition in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view with parameters of type CommitLogPosition Modifier and Type Method Description voidTableViews. truncateBlocking(CommitLogPosition replayAfter, long truncatedAt) -
Uses of CommitLogPosition in org.apache.cassandra.io.sstable
Method parameters in org.apache.cassandra.io.sstable with type arguments of type CommitLogPosition Modifier and Type Method Description static SSTableMultiWriterSimpleSSTableMultiWriter. create(Descriptor descriptor, long keyCount, long repairedAt, TimeUUID pendingRepair, boolean isTransient, TableMetadataRef metadata, IntervalSet<CommitLogPosition> commitLogPositions, int sstableLevel, SerializationHeader header, java.util.Collection<Index.Group> indexGroups, LifecycleNewTracker lifecycleNewTracker, SSTable.Owner owner) -
Uses of CommitLogPosition in org.apache.cassandra.io.sstable.metadata
Fields in org.apache.cassandra.io.sstable.metadata with type parameters of type CommitLogPosition Modifier and Type Field Description protected IntervalSet<CommitLogPosition>MetadataCollector. commitLogIntervalsIntervalSet<CommitLogPosition>StatsMetadata. commitLogIntervalsstatic ISerializer<IntervalSet<CommitLogPosition>>StatsMetadata. commitLogPositionSetSerializerMethod parameters in org.apache.cassandra.io.sstable.metadata with type arguments of type CommitLogPosition Modifier and Type Method Description MetadataCollectorMetadataCollector. commitLogIntervals(IntervalSet<CommitLogPosition> commitLogIntervals)Constructor parameters in org.apache.cassandra.io.sstable.metadata with type arguments of type CommitLogPosition Constructor Description StatsMetadata(EstimatedHistogram estimatedPartitionSize, EstimatedHistogram estimatedCellPerPartitionCount, IntervalSet<CommitLogPosition> commitLogIntervals, long minTimestamp, long maxTimestamp, long minLocalDeletionTime, long maxLocalDeletionTime, int minTTL, int maxTTL, double compressionRatio, TombstoneHistogram estimatedTombstoneDropTime, int sstableLevel, java.util.List<AbstractType<?>> clusteringTypes, Slice coveredClustering, boolean hasLegacyCounterShards, long repairedAt, long totalColumnsSet, long totalRows, double tokenSpaceCoverage, java.util.UUID originatingHostId, TimeUUID pendingRepair, boolean isTransient, boolean hasPartitionLevelDeletions, java.nio.ByteBuffer firstKey, java.nio.ByteBuffer lastKey)
-