Modifier and Type | Field and Description |
---|---|
Pair<java.lang.String,java.lang.String> |
CacheKey.ksAndCFName |
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<Pair<K,V>> |
AutoSavingCache.CacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
Modifier and Type | Method and Description |
---|---|
static CounterCacheKey |
CounterCacheKey.create(Pair<java.lang.String,java.lang.String> ksAndCFName,
java.nio.ByteBuffer partitionKey,
Clustering clustering,
ColumnDefinition c,
CellPath path) |
Constructor and Description |
---|
CacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName) |
CounterCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
java.nio.ByteBuffer partitionKey,
java.nio.ByteBuffer cellName) |
KeyCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
Descriptor desc,
java.nio.ByteBuffer key) |
RowCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
byte[] key) |
RowCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
java.nio.ByteBuffer key) |
RowCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
DecoratedKey key) |
Modifier and Type | Field and Description |
---|---|
Pair<java.lang.String,java.lang.String> |
CFMetaData.ksAndCFName |
Modifier and Type | Method and Description |
---|---|
Pair<java.lang.String,java.lang.String> |
Schema.getCF(java.util.UUID cfId) |
Modifier and Type | Method and Description |
---|---|
ColumnFamilyStore |
Schema.getColumnFamilyStoreIncludingIndexes(Pair<java.lang.String,java.lang.String> ksNameAndCFName)
Retrieve a CFS by name even if that CFS is an index
An index is identified by looking for '.' in the CF name and separating to find the base table
containing the index
|
boolean |
Schema.hasCF(Pair<java.lang.String,java.lang.String> ksAndCFName) |
Modifier and Type | Field and Description |
---|---|
java.util.List<Pair<Term.Raw,Term.Raw>> |
Maps.Literal.entries |
Modifier and Type | Method and Description |
---|---|
static WhereClause |
SuperColumnCompatibility.prepareUpdateOperations(CFMetaData cfm,
WhereClause whereClause,
java.util.List<Pair<ColumnDefinition.Raw,Operation.RawUpdate>> updates,
VariableSpecifications boundNames,
Operations operations)
For _dense_ SuperColumn Families.
|
Constructor and Description |
---|
Literal(java.util.List<Pair<Term.Raw,Term.Raw>> entries) |
Constructor and Description |
---|
Parsed(CFName name,
Attributes.Raw attrs,
java.util.List<Operation.RawDeletion> deletions,
WhereClause whereClause,
java.util.List<Pair<ColumnDefinition.Raw,ColumnCondition.Raw>> conditions,
boolean ifExists) |
Parsed(CFName name,
StatementType type,
Attributes.Raw attrs,
java.util.List<Pair<ColumnDefinition.Raw,ColumnCondition.Raw>> conditions,
boolean ifNotExists,
boolean ifExists) |
ParsedUpdate(CFName name,
Attributes.Raw attrs,
java.util.List<Pair<ColumnDefinition.Raw,Operation.RawUpdate>> updates,
WhereClause whereClause,
java.util.List<Pair<ColumnDefinition.Raw,ColumnCondition.Raw>> conditions,
boolean ifExists)
Creates a new UpdateStatement from a column family name, columns map, consistency
level, and key term.
|
ParsedUpdate(CFName name,
Attributes.Raw attrs,
java.util.List<Pair<ColumnDefinition.Raw,Operation.RawUpdate>> updates,
WhereClause whereClause,
java.util.List<Pair<ColumnDefinition.Raw,ColumnCondition.Raw>> conditions,
boolean ifExists)
Creates a new UpdateStatement from a column family name, columns map, consistency
level, and key term.
|
Modifier and Type | Method and Description |
---|---|
static Pair<LegacyLayout.LegacyRangeTombstoneList,java.util.Iterator<LegacyLayout.LegacyCell>> |
LegacyLayout.fromRowIterator(RowIterator iterator) |
static Pair<java.lang.Integer,Token> |
SystemKeyspace.getViewBuildStatus(java.lang.String ksname,
java.lang.String viewName) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<java.lang.String,Pair<java.lang.Long,java.lang.Long>> |
ColumnFamilyStore.getSnapshotDetails() |
java.util.Map<java.lang.String,Pair<java.lang.Long,java.lang.Long>> |
Directories.getSnapshotDetails() |
static java.util.List<Pair<java.lang.String,java.lang.String>> |
SystemKeyspace.loadPreparedStatements() |
Modifier and Type | Method and Description |
---|---|
static void |
SnapshotDetailsTabularData.from(java.lang.String snapshot,
java.lang.String ks,
java.lang.String cf,
java.util.Map.Entry<java.lang.String,Pair<java.lang.Long,java.lang.Long>> snapshotDetail,
javax.management.openmbean.TabularDataSupport result) |
static void |
SystemKeyspace.updateSizeEstimates(java.lang.String keyspace,
java.lang.String table,
java.util.Map<Range<Token>,Pair<java.lang.Long,java.lang.Long>> estimates)
Writes the current partition count and size estimates into SIZE_ESTIMATES_CF
|
Modifier and Type | Method and Description |
---|---|
static Pair<java.lang.Long,java.lang.Long> |
TimeWindowCompactionStrategy.getWindowBoundsInMillis(java.util.concurrent.TimeUnit windowTimeUnit,
int windowTimeSize,
long timestampInMillis)
Find the lowest and highest timestamps in a given timestamp/unit pair
Returns milliseconds, caller should adjust accordingly
|
Modifier and Type | Method and Description |
---|---|
static java.util.List<Pair<SSTableReader,java.lang.Long>> |
SizeTieredCompactionStrategy.createSSTableAndLengthPairs(java.lang.Iterable<SSTableReader> sstables) |
static java.util.List<Pair<SSTableReader,java.lang.Long>> |
DateTieredCompactionStrategy.createSSTableAndMinTimestampPairs(java.lang.Iterable<SSTableReader> sstables)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static <T> java.util.List<java.util.List<T>> |
SizeTieredCompactionStrategy.getBuckets(java.util.Collection<Pair<T,java.lang.Long>> files,
double bucketHigh,
double bucketLow,
long minSSTableSize) |
Modifier and Type | Method and Description |
---|---|
Pair<Pair<java.lang.String,java.nio.ByteBuffer>,java.util.List<Pair<java.nio.ByteBuffer,AbstractType>>> |
TypeParser.getUserTypeParameters() |
Modifier and Type | Method and Description |
---|---|
Pair<Pair<java.lang.String,java.nio.ByteBuffer>,java.util.List<Pair<java.nio.ByteBuffer,AbstractType>>> |
TypeParser.getUserTypeParameters() |
Pair<Pair<java.lang.String,java.nio.ByteBuffer>,java.util.List<Pair<java.nio.ByteBuffer,AbstractType>>> |
TypeParser.getUserTypeParameters() |
Modifier and Type | Method and Description |
---|---|
abstract Pair<AbstractBounds<T>,AbstractBounds<T>> |
AbstractBounds.split(T position)
Given token T and AbstractBounds ?L,R?, returns Pair(?L,T], (T,R?),
where ? means that the same type of AbstractBounds is returned as the original.
|
Pair<AbstractBounds<T>,AbstractBounds<T>> |
Bounds.split(T position) |
Pair<AbstractBounds<T>,AbstractBounds<T>> |
ExcludingBounds.split(T position) |
Pair<AbstractBounds<T>,AbstractBounds<T>> |
IncludingExcludingBounds.split(T position) |
Pair<AbstractBounds<T>,AbstractBounds<T>> |
Range.split(T position) |
Modifier and Type | Method and Description |
---|---|
void |
Gossiper.addLocalApplicationStates(java.util.List<Pair<ApplicationState,VersionedValue>> states) |
Modifier and Type | Method and Description |
---|---|
static Pair<ColumnDefinition,IndexTarget.Type> |
TargetParser.parse(CFMetaData cfm,
IndexMetadata indexDef) |
static Pair<ColumnDefinition,IndexTarget.Type> |
TargetParser.parse(CFMetaData cfm,
java.lang.String target) |
Modifier and Type | Method and Description |
---|---|
protected Pair<java.lang.Long,AbstractTokenTreeBuilder.InteriorNode> |
AbstractTokenTreeBuilder.InteriorNode.splitBlock() |
Modifier and Type | Method and Description |
---|---|
java.util.Iterator<Pair<java.lang.Long,com.carrotsearch.hppc.LongSet>> |
DynamicTokenTreeBuilder.iterator() |
java.util.Iterator<Pair<java.lang.Long,com.carrotsearch.hppc.LongSet>> |
StaticTokenTreeBuilder.iterator() |
Modifier and Type | Method and Description |
---|---|
protected void |
OnDiskIndexBuilder.finish(Descriptor descriptor,
Pair<java.nio.ByteBuffer,java.nio.ByteBuffer> range,
java.io.File file,
TermIterator terms) |
void |
OnDiskIndexBuilder.finish(Pair<java.nio.ByteBuffer,java.nio.ByteBuffer> range,
java.io.File file,
TermIterator terms) |
Modifier and Type | Method and Description |
---|---|
void |
DynamicTokenTreeBuilder.add(java.util.Iterator<Pair<java.lang.Long,com.carrotsearch.hppc.LongSet>> data) |
void |
StaticTokenTreeBuilder.add(java.util.Iterator<Pair<java.lang.Long,com.carrotsearch.hppc.LongSet>> data) |
void |
TokenTreeBuilder.add(java.util.Iterator<Pair<java.lang.Long,com.carrotsearch.hppc.LongSet>> data) |
Modifier and Type | Method and Description |
---|---|
protected Pair<IndexedTerm,TokenTreeBuilder> |
CombinedTermIterator.computeNext() |
Modifier and Type | Method and Description |
---|---|
CompressionMetadata.Chunk[] |
CompressionMetadata.getChunksForSections(java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections) |
long |
CompressionMetadata.getTotalSizeForSections(java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections) |
Modifier and Type | Method and Description |
---|---|
Pair<DecoratedKey,DecoratedKey> |
IndexSummary.IndexSummarySerializer.deserializeFirstLastKey(java.io.DataInputStream in,
IPartitioner partitioner,
boolean haveSamplingLevel)
Deserializes the first and last key stored in the summary
Only for use by offline tools like SSTableMetadataViewer, otherwise SSTable.first/last should be used.
|
static Pair<Descriptor,Component> |
Component.fromFilename(java.io.File directory,
java.lang.String name)
Filename of the form "<ksname>/<cfname>-[tmp-][<version>-]<gen>-<component>",
|
static Pair<Descriptor,java.lang.String> |
Descriptor.fromFilename(java.io.File directory,
java.lang.String name) |
static Pair<Descriptor,java.lang.String> |
Descriptor.fromFilename(java.io.File directory,
java.lang.String name,
boolean skipComponent)
Filename of the form is vary by version:
<ksname>-<cfname>-(tmp-)?<version>-<gen>-<component> for cassandra 2.0 and before
(<tmp marker>-)?<version>-<gen>-<component> for cassandra 3.0 and later
If this is for SSTable of secondary index, directory should ends with index name for 2.1+.
|
static Pair<Descriptor,Component> |
SSTable.tryComponentFromFilename(java.io.File dir,
java.lang.String name) |
Modifier and Type | Method and Description |
---|---|
java.util.List<Pair<java.lang.Long,java.lang.Long>> |
SSTableReader.getPositionsForRanges(java.util.Collection<Range<Token>> ranges)
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
|
Modifier and Type | Method and Description |
---|---|
Pair<java.lang.String,java.lang.String> |
TokenMetadata.Topology.getLocation(java.net.InetAddress addr) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<Pair<Token,java.net.InetAddress>> |
TokenMetadata.getMovingEndpoints()
Endpoints which are migrating to the new tokens
|
Modifier and Type | Method and Description |
---|---|
void |
RepairSession.waitForSync(Pair<RepairJobDesc,NodePair> key,
RemoteSyncTask task) |
void |
RepairSession.waitForValidation(Pair<RepairJobDesc,java.net.InetAddress> key,
ValidationTask task) |
Modifier and Type | Method and Description |
---|---|
static Pair<java.util.UUID,java.util.UUID> |
SchemaKeyspace.calculateSchemaDigest()
Read schema from system keyspace and calculate MD5 digest of every row, resulting digest
will be converted into UUID which would act as content-based version of the schema.
|
Modifier and Type | Method and Description |
---|---|
Pair<java.util.Set<Range<Token>>,java.util.Set<Range<Token>>> |
StorageService.calculateStreamAndFetchRanges(java.util.Collection<Range<Token>> current,
java.util.Collection<Range<Token>> updated)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
|
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<Pair<CounterCacheKey,ClockAndCount>> |
CacheService.CounterCacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
java.util.concurrent.Future<Pair<RowCacheKey,IRowCacheEntry>> |
CacheService.RowCacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
java.util.concurrent.Future<Pair<KeyCacheKey,RowIndexEntry>> |
CacheService.KeyCacheSerializer.deserialize(DataInputPlus input,
ColumnFamilyStore cfs) |
java.util.List<Pair<Range<Token>,java.lang.Long>> |
StorageService.getSplits(java.lang.String keyspaceName,
java.lang.String cfName,
Range<Token> range,
int keysPerSplit) |
Modifier and Type | Method and Description |
---|---|
void |
CacheService.invalidateCounterCacheForCf(Pair<java.lang.String,java.lang.String> ksAndCFName) |
void |
CacheService.invalidateKeyCacheForCf(Pair<java.lang.String,java.lang.String> ksAndCFName) |
void |
CacheService.invalidateRowCacheForCf(Pair<java.lang.String,java.lang.String> ksAndCFName) |
Modifier and Type | Field and Description |
---|---|
protected java.util.Collection<Pair<java.lang.Long,java.lang.Long>> |
StreamReader.sections |
java.util.List<Pair<java.lang.Long,java.lang.Long>> |
StreamSession.SSTableStreamingSections.sections |
protected java.util.Collection<Pair<java.lang.Long,java.lang.Long>> |
StreamWriter.sections |
Modifier and Type | Method and Description |
---|---|
void |
StreamTransferTask.addTransferFile(Ref<SSTableReader> ref,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long repairedAt) |
Constructor and Description |
---|
SSTableStreamingSections(Ref<SSTableReader> ref,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long estimatedKeys,
long repairedAt) |
StreamWriter(SSTableReader sstable,
java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections,
StreamSession session) |
Constructor and Description |
---|
CompressedStreamWriter(SSTableReader sstable,
java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections,
CompressionInfo compressionInfo,
StreamSession session) |
Modifier and Type | Field and Description |
---|---|
java.util.List<Pair<java.lang.Long,java.lang.Long>> |
FileMessageHeader.sections |
Constructor and Description |
---|
FileMessageHeader(java.util.UUID cfId,
int sequenceNumber,
Version version,
SSTableFormat.Type format,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
CompressionInfo compressionInfo,
long repairedAt,
int sstableLevel,
SerializationHeader.Component header) |
FileMessageHeader(java.util.UUID cfId,
int sequenceNumber,
Version version,
SSTableFormat.Type format,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
CompressionMetadata compressionMetadata,
long repairedAt,
int sstableLevel,
SerializationHeader.Component header) |
OutgoingFileMessage(Ref<SSTableReader> ref,
int sequenceNumber,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long repairedAt,
boolean keepSSTableLevel) |
Modifier and Type | Method and Description |
---|---|
Pair<DataType,java.lang.Object> |
DataType.Codec.decodeOne(io.netty.buffer.ByteBuf body,
ProtocolVersion version) |
static Pair<DataType,java.lang.Object> |
DataType.fromType(AbstractType type,
ProtocolVersion version) |
static Pair<java.util.List<java.lang.String>,java.util.List<java.nio.ByteBuffer>> |
CBUtil.readNameAndValueList(io.netty.buffer.ByteBuf cb,
ProtocolVersion protocolVersion) |
Modifier and Type | Method and Description |
---|---|
int |
DataType.Codec.oneSerializedSize(Pair<DataType,java.lang.Object> option,
ProtocolVersion version) |
static AbstractType |
DataType.toType(Pair<DataType,java.lang.Object> entry) |
void |
DataType.Codec.writeOne(Pair<DataType,java.lang.Object> option,
io.netty.buffer.ByteBuf dest,
ProtocolVersion version) |
Modifier and Type | Method and Description |
---|---|
static <X,Y> Pair<X,Y> |
Pair.create(X x,
Y y) |
static Pair<java.math.BigInteger,java.lang.Boolean> |
FBUtilities.midpoint(java.math.BigInteger left,
java.math.BigInteger right,
int sigbits)
Given two bit arrays represented as BigIntegers, containing the given
number of significant bits, calculate a midpoint.
|
Constructor and Description |
---|
ExpiringMap(long defaultExpiration,
com.google.common.base.Function<Pair<K,ExpiringMap.CacheableObject<V>>,?> postExpireHook) |
Copyright © 2020 The Apache Software Foundation