Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<Pair<K,V>> |
AutoSavingCache.CacheSerializer.deserialize(DataInputPlus in,
ColumnFamilyStore cfs) |
Modifier and Type | Field and Description |
---|---|
java.util.List<Pair<Term.Raw,Term.Raw>> |
Maps.Literal.entries |
Modifier and Type | Method and Description |
---|---|
static <T> AbstractType<?> |
Maps.getExactMapTypeIfKnown(java.util.List<Pair<T,T>> entries,
java.util.function.Function<T,AbstractType<?>> mapper)
Returns the exact MapType from the entries if it can be known.
|
static <T> java.lang.String |
Maps.mapToString(java.util.List<Pair<T,T>> entries)
Create a
String representation of the list containing the specified elements. |
static <T> java.lang.String |
Maps.mapToString(java.util.List<Pair<T,T>> items,
java.util.function.Function<T,java.lang.String> mapper)
Create a
String representation of the map from the specified items associated to
the map entries. |
static <T extends AssignmentTestable> |
Maps.testMapAssignment(ColumnSpecification receiver,
java.util.List<Pair<T,T>> entries)
Tests that the map with the specified entries can be assigned to the specified column.
|
Constructor and Description |
---|
Literal(java.util.List<Pair<Term.Raw,Term.Raw>> entries) |
Constructor and Description |
---|
Raw(java.util.List<Pair<Selectable.Raw,Selectable.Raw>> raws) |
WithMapOrUdt(TableMetadata cfm,
java.util.List<Pair<Selectable.Raw,Selectable.Raw>> raws) |
Modifier and Type | Method and Description |
---|---|
java.util.List<Pair<ColumnIdentifier,ColumnCondition.Raw>> |
ModificationStatement.Parsed.getConditions() |
Constructor and Description |
---|
Parsed(QualifiedName name,
Attributes.Raw attrs,
java.util.List<Operation.RawDeletion> deletions,
WhereClause whereClause,
java.util.List<Pair<ColumnIdentifier,ColumnCondition.Raw>> conditions,
boolean ifExists) |
Parsed(QualifiedName name,
StatementType type,
Attributes.Raw attrs,
java.util.List<Pair<ColumnIdentifier,ColumnCondition.Raw>> conditions,
boolean ifNotExists,
boolean ifExists) |
ParsedUpdate(QualifiedName name,
Attributes.Raw attrs,
java.util.List<Pair<ColumnIdentifier,Operation.RawUpdate>> updates,
WhereClause whereClause,
java.util.List<Pair<ColumnIdentifier,ColumnCondition.Raw>> conditions,
boolean ifExists)
Creates a new UpdateStatement from a column family name, columns map, consistency
level, and key term.
|
ParsedUpdate(QualifiedName name,
Attributes.Raw attrs,
java.util.List<Pair<ColumnIdentifier,Operation.RawUpdate>> updates,
WhereClause whereClause,
java.util.List<Pair<ColumnIdentifier,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 java.util.Map<Range<Token>,Pair<Token,java.lang.Long>> |
SystemKeyspace.getViewBuildStatus(java.lang.String ksname,
java.lang.String viewName) |
static java.util.List<Pair<java.lang.String,java.lang.String>> |
SystemKeyspace.loadPreparedStatements() |
Modifier and Type | Method and Description |
---|---|
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
|
static void |
SystemKeyspace.updateTableEstimates(java.lang.String keyspace,
java.lang.String table,
java.lang.String type,
java.util.Map<Range<Token>,Pair<java.lang.Long,java.lang.Long>> estimates)
Writes the current partition count and size estimates into table_estimates
|
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<java.lang.String,java.lang.String> |
ConfigHelper.getInputKeyRange(org.apache.hadoop.conf.Configuration conf)
The start and end token of the input key range as a pair.
|
Modifier and Type | Method and Description |
---|---|
static Pair<ColumnMetadata,IndexTarget.Type> |
TargetParser.parse(TableMetadata metadata,
IndexMetadata indexDef) |
static Pair<ColumnMetadata,IndexTarget.Type> |
TargetParser.parse(TableMetadata metadata,
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 |
---|---|
Pair<DecoratedKey,DecoratedKey> |
IndexSummary.IndexSummarySerializer.deserializeFirstLastKey(java.io.DataInputStream in,
IPartitioner partitioner)
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> |
Descriptor.fromFilenameWithComponent(java.io.File file)
Parse a sstable filename, extracting both the
Descriptor and Component part. |
static Pair<Descriptor,Component> |
SSTable.tryComponentFromFilename(java.io.File file)
Parse a sstable filename into both a
Descriptor and Component object. |
Modifier and Type | Method and Description |
---|---|
Pair<java.lang.String,java.lang.String> |
TokenMetadata.Topology.getLocation(InetAddressAndPort addr) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<Pair<Token,InetAddressAndPort>> |
TokenMetadata.getMovingEndpoints()
Endpoints which are migrating to the new tokens
|
Modifier and Type | Method and Description |
---|---|
void |
RepairSession.trackSyncCompletion(Pair<RepairJobDesc,SyncNodePair> key,
CompletableRemoteSyncTask task) |
void |
RepairSession.trackValidationCompletion(Pair<RepairJobDesc,InetAddressAndPort> key,
ValidationTask task) |
Modifier and Type | Method and Description |
---|---|
static Pair<RangesAtEndpoint,RangesAtEndpoint> |
RangeRelocator.calculateStreamAndFetchRanges(RangesAtEndpoint currentRanges,
RangesAtEndpoint updatedRanges)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
With transient replication the added wrinkle is that if a range transitions from full to transient then
we need to stream the range despite the fact that we are retaining it as transient.
|
Pair<java.lang.Integer,java.util.concurrent.Future<?>> |
StorageService.repair(java.lang.String keyspace,
java.util.Map<java.lang.String,java.lang.String> repairSpec,
java.util.List<ProgressListener> listeners) |
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 |
---|---|
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.
|
Copyright © 2009-2020 The Apache Software Foundation