Uses of Class
org.apache.cassandra.locator.Replica
-
-
Uses of Replica in org.apache.cassandra.config
Methods in org.apache.cassandra.config that return types with arguments of type Replica Modifier and Type Method Description static java.util.Comparator<Replica>
DatabaseDescriptor. getLocalComparator()
-
Uses of Replica in org.apache.cassandra.db
Methods in org.apache.cassandra.db with parameters of type Replica Modifier and Type Method Description ReadCommand
ReadCommand. copyAsDigestQuery(Replica replica)
Returns a copy of this command with isDigestQuery set to true.ReadCommand
ReadCommand. copyAsTransientQuery(Replica replica)
Returns a copy of this command with acceptsTransient set to true.Method parameters in org.apache.cassandra.db with type arguments of type Replica Modifier and Type Method Description ReadCommand
ReadCommand. copyAsDigestQuery(java.lang.Iterable<Replica> replicas)
Returns a copy of this command with isDigestQuery set to true.ReadCommand
ReadCommand. copyAsTransientQuery(java.lang.Iterable<Replica> replicas)
Returns a copy of this command with acceptsTransient set to true. -
Uses of Replica in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view that return types with arguments of type Replica Modifier and Type Method Description static java.util.Optional<Replica>
ViewUtils. getViewNaturalEndpoint(AbstractReplicationStrategy replicationStrategy, Token baseToken, Token viewToken)
Calculate the natural endpoint for the view. -
Uses of Replica in org.apache.cassandra.dht
Fields in org.apache.cassandra.dht declared as Replica Modifier and Type Field Description Replica
RangeStreamer.FetchReplica. local
Replica
RangeStreamer.FetchReplica. remote
Fields in org.apache.cassandra.dht with type parameters of type Replica Modifier and Type Field Description static com.google.common.base.Predicate<Replica>
RangeStreamer. ALIVE_PREDICATE
Methods in org.apache.cassandra.dht with parameters of type Replica Modifier and Type Method Description boolean
RangeStreamer.AllowedSourcesFilter. apply(Replica replica)
boolean
RangeStreamer.ExcludeLocalNodeFilter. apply(Replica replica)
boolean
RangeStreamer.FailureDetectorSourceFilter. apply(Replica replica)
boolean
RangeStreamer.SingleDatacenterFilter. apply(Replica replica)
boolean
RangeStreamer.SourceFilter. apply(Replica replica)
java.lang.String
RangeStreamer.AllowedSourcesFilter. message(Replica replica)
java.lang.String
RangeStreamer.ExcludeLocalNodeFilter. message(Replica replica)
java.lang.String
RangeStreamer.FailureDetectorSourceFilter. message(Replica replica)
java.lang.String
RangeStreamer.SingleDatacenterFilter. message(Replica replica)
java.lang.String
RangeStreamer.SourceFilter. message(Replica replica)
Constructors in org.apache.cassandra.dht with parameters of type Replica Constructor Description FetchReplica(Replica local, Replica remote)
-
Uses of Replica in org.apache.cassandra.gms
Fields in org.apache.cassandra.gms with type parameters of type Replica Modifier and Type Field Description static java.util.function.Predicate<Replica>
FailureDetector. isReplicaAlive
-
Uses of Replica in org.apache.cassandra.locator
Methods in org.apache.cassandra.locator that return Replica Modifier and Type Method Description Replica
Replica. decorateSubrange(Range<Token> subrange)
Replica
ReplicaPlan.ForRead. firstUncontactedCandidate(java.util.function.Predicate<Replica> extraPredicate)
static Replica
Replica. fullReplica(InetAddressAndPort endpoint, Range<Token> range)
static Replica
Replica. fullReplica(InetAddressAndPort endpoint, Token start, Token end)
Replica
AbstractReplicaCollection. get(int i)
Replica
AbstractReplicaCollection.ReplicaList. get(int index)
Replica
AbstractReplicaCollection.ReplicaMap. get(java.lang.Object key)
Replica
ReplicaCollection. get(int i)
Replica
AbstractReplicationStrategy. getLocalReplicaFor(RingPosition<?> searchPosition)
static Replica
SystemReplicas. getSystemReplica(InetAddressAndPort endpoint)
There are a few places where a system function borrows write path functionality, but doesn't otherwise fit into normal replication strategies (ie: hints and batchlog).Replica
ReplicaPlan.ForRead. lookup(InetAddressAndPort endpoint)
Replica
ReplicaPlan.ForWrite. lookup(InetAddressAndPort endpoint)
Replica
AbstractReplicaCollection.ReplicaMap. remove(java.lang.Object key)
Replica
Endpoints. selfIfPresent()
static Replica
Replica. transientReplica(InetAddressAndPort endpoint, Range<Token> range)
static Replica
Replica. transientReplica(InetAddressAndPort endpoint, Token start, Token end)
Methods in org.apache.cassandra.locator that return types with arguments of type Replica Modifier and Type Method Description java.util.Map<InetAddressAndPort,Replica>
Endpoints. byEndpoint()
java.util.Map<Range<Token>,Replica>
RangesAtEndpoint. byRange()
static <C extends ReplicaCollection<C>,B extends ReplicaCollection.Builder<C>>
java.util.stream.Collector<Replica,B,C>AbstractReplicaCollection. collector(java.util.Set<java.util.stream.Collector.Characteristics> characteristics, java.util.function.Supplier<B> supplier)
static java.util.stream.Collector<Replica,RangesAtEndpoint.Builder,RangesAtEndpoint>
RangesAtEndpoint. collector(InetAddressAndPort endpoint)
java.util.Set<java.util.Map.Entry<K,Replica>>
AbstractReplicaCollection.ReplicaMap. entrySet()
java.lang.Iterable<Replica>
AbstractReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate)
java.lang.Iterable<Replica>
AbstractReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate, int limit)
java.lang.Iterable<Replica>
ReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate)
java.lang.Iterable<Replica>
ReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate, int maxSize)
java.lang.Iterable<java.util.Map.Entry<K,Replica>>
ReplicaMultimap. flattenEntries()
java.lang.Iterable<Replica>
ReplicaMultimap. flattenValues()
java.util.Iterator<Replica>
AbstractReplicaCollection. iterator()
java.util.Iterator<Replica>
AbstractReplicaCollection.ReplicaList. iterator()
java.util.Iterator<Replica>
ReplicaCollection. iterator()
static java.util.function.Predicate<Replica>
InOurDcTester. replicas()
java.util.stream.Stream<Replica>
AbstractReplicaCollection.ReplicaList. stream()
java.util.stream.Stream<Replica>
AbstractReplicaCollection. stream()
java.util.stream.Stream<Replica>
ReplicaCollection. stream()
Methods in org.apache.cassandra.locator with parameters of type Replica Modifier and Type Method Description void
AbstractReplicaCollection.ReplicaList. add(Replica replica)
EndpointsForRange.Builder
EndpointsForRange.Builder. add(Replica replica, ReplicaCollection.Builder.Conflict ignoreConflict)
EndpointsForToken.Builder
EndpointsForToken.Builder. add(Replica replica, ReplicaCollection.Builder.Conflict ignoreConflict)
RangesAtEndpoint.Builder
RangesAtEndpoint.Builder. add(Replica replica)
RangesAtEndpoint.Builder
RangesAtEndpoint.Builder. add(Replica replica, ReplicaCollection.Builder.Conflict ignoreConflict)
default ReplicaCollection.Builder<C>
ReplicaCollection.Builder. add(Replica replica)
ReplicaCollection.Builder<C>
ReplicaCollection.Builder. add(Replica replica, ReplicaCollection.Builder.Conflict ignoreConflict)
void
PendingRangeMaps. addPendingRange(Range<Token> range, Replica replica)
void
ReplicaPlan.Shared. addToContacts(Replica replica)
add the provided replica to this shared plan, by updating the internal referencevoid
ReplicaPlan.SharedForRangeRead. addToContacts(Replica replica)
void
ReplicaPlan.SharedForTokenRead. addToContacts(Replica replica)
static <E extends Endpoints<E>>
EEndpoints. append(E replicas, Replica extraReplica)
abstract int
AbstractEndpointSnitch. compareEndpoints(InetAddressAndPort target, Replica r1, Replica r2)
int
AbstractNetworkTopologySnitch. compareEndpoints(InetAddressAndPort address, Replica r1, Replica r2)
int
DynamicEndpointSnitch. compareEndpoints(InetAddressAndPort target, Replica a1, Replica a2)
int
IEndpointSnitch. compareEndpoints(InetAddressAndPort target, Replica r1, Replica r2)
compares two endpoints in relation to the target endpoint, returning as Comparator.compare wouldint
SimpleSnitch. compareEndpoints(InetAddressAndPort target, Replica r1, Replica r2)
int
Replica. compareTo(Replica o)
boolean
ReplicaPlan. contacts(Replica replica)
boolean
Endpoints. contains(Replica replica)
boolean
RangesAtEndpoint. contains(Replica replica)
boolean
ReplicaCollection. contains(Replica replica)
static ReplicaPlan.ForTokenWrite
ReplicaPlans. forForwardingCounterWrite(Keyspace keyspace, Token token, Replica replica)
A forwarding counter write is always sent to a single owning coordinator for the range, by the original coordinator (if it is not itself an owner)static ReplicaPlan.ForRangeRead
ReplicaPlans. forSingleReplicaRead(Keyspace keyspace, AbstractBounds<PartitionPosition> range, Replica replica, int vnodeCount)
Construct a plan for reading from a single node - this permits no speculation or read-repairstatic ReplicaPlan.ForTokenRead
ReplicaPlans. forSingleReplicaRead(Keyspace keyspace, Token token, Replica replica)
Construct a plan for reading from a single node - this permits no speculation or read-repairstatic ReplicaPlan.ForTokenWrite
ReplicaPlans. forSingleReplicaWrite(Keyspace keyspace, Token token, Replica replica)
Construct a ReplicaPlan for writing to exactly one node, with CL.ONE.EndpointsForRange
EndpointsByReplica. get(Replica range)
default java.lang.String
IEndpointSnitch. getDatacenter(Replica replica)
void
Replicas.ReplicaCount. increment(Replica replica)
boolean
Replica. intersectsOnRange(Replica replica)
boolean
ReplicaPlan.ForWrite. isAlive(Replica replica)
Test liveness, consistent with the upfront analysis done for this operation (i.e.protected EndpointsForRange.Builder
EndpointsByReplica.Builder. newBuilder(Replica replica)
static EndpointsForRange
EndpointsForRange. of(Replica replica)
static EndpointsForRange
EndpointsForRange. of(Replica... replicas)
static EndpointsForToken
EndpointsForToken. of(Token token, Replica replica)
static EndpointsForToken
EndpointsForToken. of(Token token, Replica... replicas)
static RangesAtEndpoint
RangesAtEndpoint. of(Replica replica)
static RangesAtEndpoint
RangesAtEndpoint. of(Replica... replicas)
void
ReplicaMultimap.Builder. put(K key, Replica replica)
void
EndpointsByReplica.Builder. putAll(Replica range, EndpointsForRange replicas, ReplicaCollection.Builder.Conflict ignoreConflicts)
static void
Replicas. temporaryAssertFull(Replica replica)
A placeholder for areas of the code that cannot yet handle transient replicas, but should do so in futureMethod parameters in org.apache.cassandra.locator with type arguments of type Replica Modifier and Type Method Description default ReplicaCollection.Builder<C>
ReplicaCollection.Builder. addAll(java.lang.Iterable<Replica> replicas)
default ReplicaCollection.Builder<C>
ReplicaCollection.Builder. addAll(java.lang.Iterable<Replica> replicas, ReplicaCollection.Builder.Conflict ignoreConflicts)
static void
Replicas. addToCountPerDc(com.carrotsearch.hppc.ObjectIntHashMap<java.lang.String> perDc, java.lang.Iterable<Replica> replicas, int add)
increment each of the map's DC entries for each matching replica providedstatic void
Replicas. assertFull(java.lang.Iterable<Replica> replicas)
For areas of the code that should never see a transient replicastatic EndpointsForRange
EndpointsForRange. copyOf(java.util.Collection<Replica> replicas)
static EndpointsForToken
EndpointsForToken. copyOf(Token token, java.util.Collection<Replica> replicas)
static RangesAtEndpoint
RangesAtEndpoint. copyOf(java.util.List<Replica> replicas)
int
AbstractReplicaCollection. count(java.util.function.Predicate<Replica> predicate)
int
ReplicaCollection. count(java.util.function.Predicate<Replica> predicate)
static com.carrotsearch.hppc.ObjectObjectHashMap<java.lang.String,Replicas.ReplicaCount>
Replicas. countPerDc(java.util.Collection<java.lang.String> dataCenters, java.lang.Iterable<Replica> replicas)
count the number of full and transient replicas, separately, for each DCC
AbstractReplicaCollection. filter(java.util.function.Predicate<Replica> predicate)
C
AbstractReplicaCollection. filter(java.util.function.Predicate<Replica> predicate, int limit)
C
ReplicaCollection. filter(java.util.function.Predicate<Replica> predicate)
C
ReplicaCollection. filter(java.util.function.Predicate<Replica> predicate, int maxSize)
ReplicaLayout.ForRangeRead
ReplicaLayout.ForRangeRead. filter(java.util.function.Predicate<Replica> filter)
ReplicaLayout.ForTokenRead
ReplicaLayout.ForTokenRead. filter(java.util.function.Predicate<Replica> filter)
ReplicaLayout.ForTokenWrite
ReplicaLayout.ForTokenWrite. filter(java.util.function.Predicate<Replica> filter)
java.lang.Iterable<Replica>
AbstractReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate)
java.lang.Iterable<Replica>
AbstractReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate, int limit)
java.lang.Iterable<Replica>
ReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate)
java.lang.Iterable<Replica>
ReplicaCollection. filterLazily(java.util.function.Predicate<Replica> predicate, int maxSize)
Replica
ReplicaPlan.ForRead. firstUncontactedCandidate(java.util.function.Predicate<Replica> extraPredicate)
static ReplicaPlan.ForTokenWrite
ReplicaPlans. forWrite(Keyspace keyspace, ConsistencyLevel consistencyLevel, EndpointsForToken natural, EndpointsForToken pending, java.util.function.Predicate<Replica> isAlive, ReplicaPlans.Selector selector)
AbstractReplicaCollection.ReplicaList
AbstractReplicaCollection.ReplicaList. sorted(java.util.Comparator<Replica> comparator)
C
AbstractReplicaCollection. sorted(java.util.Comparator<Replica> comparator)
C
ReplicaCollection. sorted(java.util.Comparator<Replica> comparator)
static void
Replicas. temporaryAssertFull(java.lang.Iterable<Replica> replicas)
A placeholder for areas of the code that cannot yet handle transient replicas, but should do so in future<K> java.util.Iterator<K>
AbstractReplicaCollection.ReplicaList. transformIterator(java.util.function.Function<Replica,K> function)
Constructors in org.apache.cassandra.locator with parameters of type Replica Constructor Description ReplicaList(Replica[] contents, int begin, int size)
Constructor parameters in org.apache.cassandra.locator with type arguments of type Replica Constructor Description EndpointsByReplica(java.util.Map<Replica,EndpointsForRange> map)
ReplicaMap(AbstractReplicaCollection.ReplicaList list, java.util.function.Function<Replica,K> toKey)
ReplicaMap(AbstractReplicaCollection.ReplicaList list, java.util.function.Function<Replica,K> toKey, com.carrotsearch.hppc.ObjectIntHashMap<K> map)
-
Uses of Replica in org.apache.cassandra.net
Methods in org.apache.cassandra.net with parameters of type Replica Modifier and Type Method Description void
RequestCallbacks. addWithExpiration(AbstractWriteResponseHandler<?> cb, Message<?> message, Replica to, ConsistencyLevel consistencyLevel, boolean allowHints)
void
MessagingService. sendWriteWithCallback(Message message, Replica to, AbstractWriteResponseHandler<?> handler, boolean allowHints)
Send a mutation message or a Paxos Commit to a given endpoint. -
Uses of Replica in org.apache.cassandra.service
Methods in org.apache.cassandra.service with parameters of type Replica Modifier and Type Method Description static boolean
StorageProxy. shouldHint(Replica replica)
static java.util.concurrent.Future<java.lang.Void>
StorageProxy. submitHint(Mutation mutation, Replica target, AbstractWriteResponseHandler<IMutation> responseHandler)
-
Uses of Replica in org.apache.cassandra.service.reads
Methods in org.apache.cassandra.service.reads with parameters of type Replica Modifier and Type Method Description static UnfilteredPartitionIterator
ShortReadProtection. extend(Replica source, java.lang.Runnable preFetchCallback, UnfilteredPartitionIterator partitions, ReadCommand command, DataLimits.Counter mergedResultCounter, long queryStartNanoTime, boolean enforceStrictLiveness)
Method parameters in org.apache.cassandra.service.reads with type arguments of type Replica Modifier and Type Method Description protected void
AbstractReadExecutor. makeDigestRequests(java.lang.Iterable<Replica> replicas)
protected void
AbstractReadExecutor. makeTransientDataRequests(java.lang.Iterable<Replica> replicas)
Constructors in org.apache.cassandra.service.reads with parameters of type Replica Constructor Description ShortReadPartitionsProtection(ReadCommand command, Replica source, java.lang.Runnable preFetchCallback, DataLimits.Counter singleResultCounter, DataLimits.Counter mergedResultCounter, long queryStartNanoTime)
-
Uses of Replica in org.apache.cassandra.service.reads.repair
Method parameters in org.apache.cassandra.service.reads.repair with type arguments of type Replica Modifier and Type Method Description void
BlockingReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
NoopReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
ReadOnlyReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
ReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
Repairs a partition _after_ receiving data responses.Constructor parameters in org.apache.cassandra.service.reads.repair with type arguments of type Replica Constructor Description BlockingPartitionRepair(DecoratedKey key, java.util.Map<Replica,Mutation> repairs, ReplicaPlan.ForTokenWrite writePlan)
BlockingPartitionRepair(DecoratedKey key, java.util.Map<Replica,Mutation> repairs, ReplicaPlan.ForTokenWrite writePlan, java.util.function.Predicate<InetAddressAndPort> shouldBlockOn)
-