Modifier and Type | Method and Description |
---|---|
InetAddressAndPort |
AuditLogEntry.getHost() |
InetAddressAndPort |
AuditLogEntry.getSource() |
Modifier and Type | Method and Description |
---|---|
static InetAddressAndPort |
DatabaseDescriptor.getReplaceAddress() |
Modifier and Type | Method and Description |
---|---|
static java.util.Set<InetAddressAndPort> |
DatabaseDescriptor.getSeeds() |
Modifier and Type | Method and Description |
---|---|
boolean |
EncryptionOptions.ServerEncryptionOptions.shouldEncrypt(InetAddressAndPort endpoint) |
Modifier and Type | Method and Description |
---|---|
static InetAddressAndPort |
SystemKeyspace.getPreferredIP(InetAddressAndPort ep)
Get preferred IP for given endpoint if it is known.
|
Modifier and Type | Method and Description |
---|---|
static java.util.Map<InetAddressAndPort,java.util.Set<Range<Token>>> |
SystemKeyspace.getTransferredRanges(java.lang.String description,
java.lang.String keyspace,
IPartitioner partitioner) |
static java.util.Map<InetAddressAndPort,java.util.Map<java.lang.String,java.lang.String>> |
SystemKeyspace.loadDcRackInfo()
Return a map of IP addresses containing a map of dc and rack info
|
static java.util.Map<InetAddressAndPort,java.util.UUID> |
SystemKeyspace.loadHostIds()
Return a map of store host_ids to IP addresses
|
static com.google.common.collect.SetMultimap<InetAddressAndPort,Token> |
SystemKeyspace.loadTokens()
Return a map of stored tokens to IP addresses
|
Modifier and Type | Method and Description |
---|---|
static InetAddressAndPort |
SystemKeyspace.getPreferredIP(InetAddressAndPort ep)
Get preferred IP for given endpoint if it is known.
|
static CassandraVersion |
SystemKeyspace.getReleaseVersion(InetAddressAndPort ep)
Get release version for given endpoint.
|
static void |
SystemKeyspace.removeEndpoint(InetAddressAndPort ep)
Remove stored tokens being used by another node
|
static void |
SystemKeyspace.updateHintsDropped(InetAddressAndPort ep,
java.util.UUID timePeriod,
int value) |
static void |
SystemKeyspace.updatePeerInfo(InetAddressAndPort ep,
java.lang.String columnName,
java.lang.Object value) |
static void |
SystemKeyspace.updatePeerNativeAddress(InetAddressAndPort ep,
InetAddressAndPort address) |
static boolean |
SystemKeyspace.updatePreferredIP(InetAddressAndPort ep,
InetAddressAndPort preferred_ip) |
static void |
SystemKeyspace.updateTokens(InetAddressAndPort ep,
java.util.Collection<Token> tokens)
Record tokens being used by another node
|
static void |
SystemKeyspace.updateTransferredRanges(StreamOperation streamOperation,
InetAddressAndPort peer,
java.lang.String keyspace,
java.util.Collection<Range<Token>> streamedRanges) |
Modifier and Type | Method and Description |
---|---|
static PartitionIterator |
DuplicateRowChecker.duringRead(PartitionIterator iterator,
java.util.List<InetAddressAndPort> replicas) |
Modifier and Type | Field and Description |
---|---|
protected InetAddressAndPort |
BootStrapper.address |
Modifier and Type | Method and Description |
---|---|
static com.google.common.collect.Multimap<InetAddressAndPort,RangeStreamer.FetchReplica> |
RangeStreamer.convertPreferredEndpointsToWorkMap(EndpointsByReplica preferredEndpoints)
The preferred endpoint list is the wrong format because it is keyed by Replica (this node) rather than the source
endpoint we will fetch from which streaming wants.
|
com.google.common.collect.Multimap<InetAddressAndPort,Range<Token>> |
RangeFetchMapCalculator.getRangeFetchMap() |
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<Token> |
BootStrapper.getBootstrapTokens(TokenMetadata metadata,
InetAddressAndPort address,
int schemaWaitDelay)
if initialtoken was specified, use that (split on comma).
|
Modifier and Type | Method and Description |
---|---|
static EndpointsByReplica |
RangeStreamer.calculateRangesToFetchWithPreferredEndpoints(java.util.function.BiFunction<InetAddressAndPort,EndpointsForRange,EndpointsForRange> snitchGetSortedListByProximity,
AbstractReplicationStrategy strat,
ReplicaCollection<?> fetchRanges,
boolean useStrictConsistency,
TokenMetadata tmdBefore,
TokenMetadata tmdAfter,
java.lang.String keyspace,
java.util.Collection<RangeStreamer.SourceFilter> sourceFilters)
Get a map of all ranges and the source that will be cleaned up once this bootstrapped node is added for the given ranges.
|
Constructor and Description |
---|
BootStrapper(InetAddressAndPort address,
java.util.Collection<Token> tokens,
TokenMetadata tmd) |
RangeStreamer(TokenMetadata metadata,
java.util.Collection<Token> tokens,
InetAddressAndPort address,
StreamOperation streamOperation,
boolean useStrictConsistency,
IEndpointSnitch snitch,
StreamStateStore stateStore,
boolean connectSequentially,
int connectionsPerHost) |
Constructor and Description |
---|
AllowedSourcesFilter(java.util.Set<InetAddressAndPort> allowedSources) |
Modifier and Type | Method and Description |
---|---|
static TokenAllocator<InetAddressAndPort> |
TokenAllocatorFactory.createTokenAllocator(java.util.NavigableMap<Token,InetAddressAndPort> sortedTokens,
org.apache.cassandra.dht.tokenallocator.ReplicationStrategy<InetAddressAndPort> strategy,
IPartitioner partitioner) |
static java.util.Map<InetAddressAndPort,java.lang.Double> |
TokenAllocation.evaluateReplicatedOwnership(TokenMetadata tokenMetadata,
AbstractReplicationStrategy rs) |
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<Token> |
TokenAllocation.allocateTokens(TokenMetadata tokenMetadata,
AbstractReplicationStrategy rs,
InetAddressAndPort endpoint,
int numTokens) |
static java.util.Collection<Token> |
TokenAllocation.allocateTokens(TokenMetadata tokenMetadata,
int replicas,
InetAddressAndPort endpoint,
int numTokens) |
static org.apache.commons.math3.stat.descriptive.SummaryStatistics |
TokenAllocation.replicatedOwnershipStats(TokenMetadata tokenMetadata,
AbstractReplicationStrategy rs,
InetAddressAndPort endpoint) |
Modifier and Type | Method and Description |
---|---|
static TokenAllocator<InetAddressAndPort> |
TokenAllocatorFactory.createTokenAllocator(java.util.NavigableMap<Token,InetAddressAndPort> sortedTokens,
org.apache.cassandra.dht.tokenallocator.ReplicationStrategy<InetAddressAndPort> strategy,
IPartitioner partitioner) |
static TokenAllocator<InetAddressAndPort> |
TokenAllocatorFactory.createTokenAllocator(java.util.NavigableMap<Token,InetAddressAndPort> sortedTokens,
org.apache.cassandra.dht.tokenallocator.ReplicationStrategy<InetAddressAndPort> strategy,
IPartitioner partitioner) |
Modifier and Type | Field and Description |
---|---|
java.util.Map<InetAddressAndPort,RequestFailureReason> |
RequestFailureException.failureReasonByEndpoint |
Constructor and Description |
---|
ReadFailureException(ConsistencyLevel consistency,
int received,
int blockFor,
boolean dataPresent,
java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint) |
RequestFailureException(ExceptionCode code,
ConsistencyLevel consistency,
int received,
int blockFor,
java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint) |
WriteFailureException(ConsistencyLevel consistency,
int received,
int blockFor,
WriteType writeType,
java.util.Map<InetAddressAndPort,RequestFailureReason> failureReasonByEndpoint) |
Modifier and Type | Field and Description |
---|---|
static java.util.function.Predicate<InetAddressAndPort> |
FailureDetector.isEndpointAlive |
Modifier and Type | Method and Description |
---|---|
java.util.Map<InetAddressAndPort,EndpointState> |
Gossiper.doShadowRound() |
java.util.Map<InetAddressAndPort,EndpointState> |
Gossiper.doShadowRound(java.util.Set<InetAddressAndPort> peers)
Do a single 'shadow' round of gossip by retrieving endpoint states that will be stored exclusively in the
map return value, instead of endpointStateMap.
|
com.google.common.collect.ImmutableSet<InetAddressAndPort> |
Gossiper.getEndpoints() |
java.util.Set<InetAddressAndPort> |
Gossiper.getLiveMembers() |
java.util.Set<InetAddressAndPort> |
Gossiper.getLiveTokenOwners() |
java.util.Set<InetAddressAndPort> |
Gossiper.getUnreachableMembers() |
java.util.Set<InetAddressAndPort> |
Gossiper.getUnreachableTokenOwners() |
Modifier and Type | Method and Description |
---|---|
void |
Gossiper.addExpireTimeForEndpoint(InetAddressAndPort endpoint,
long expireTime) |
void |
Gossiper.addSavedEndpoint(InetAddressAndPort ep)
Add an endpoint we knew about previously, but whose state is unknown
|
void |
Gossiper.advertiseRemoving(InetAddressAndPort endpoint,
java.util.UUID hostId,
java.util.UUID localHostId)
This method will begin removing an existing endpoint from the cluster by spoofing its state
This should never be called unless this coordinator has had 'removenode' invoked
|
void |
Gossiper.advertiseTokenRemoved(InetAddressAndPort endpoint,
java.util.UUID hostId)
Handles switching the endpoint's state from REMOVING_TOKEN to REMOVED_TOKEN
This should only be called after advertiseRemoving
|
void |
IEndpointStateChangeSubscriber.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
VersionedValue |
VersionedValue.VersionedValueFactory.bootReplacingWithPort(InetAddressAndPort oldNode) |
int |
Gossiper.compareEndpointStartup(InetAddressAndPort addr1,
InetAddressAndPort addr2)
determine which endpoint started up earlier
|
void |
Gossiper.convict(InetAddressAndPort endpoint,
double phi)
This method is part of IFailureDetectionEventListener interface.
|
void |
IFailureDetectionEventListener.convict(InetAddressAndPort ep,
double phi)
Convict the specified endpoint.
|
void |
FailureDetector.forceConviction(InetAddressAndPort ep) |
void |
IFailureDetector.forceConviction(InetAddressAndPort ep)
force conviction of endpoint in the failure detector
|
int |
Gossiper.getCurrentGenerationNumber(InetAddressAndPort endpoint) |
long |
Gossiper.getEndpointDowntime(InetAddressAndPort ep) |
EndpointState |
Gossiper.getEndpointStateForEndpoint(InetAddressAndPort ep) |
protected long |
Gossiper.getExpireTimeForEndpoint(InetAddressAndPort endpoint) |
java.util.UUID |
Gossiper.getHostId(InetAddressAndPort endpoint) |
java.util.UUID |
Gossiper.getHostId(InetAddressAndPort endpoint,
java.util.Map<InetAddressAndPort,EndpointState> epStates) |
CassandraVersion |
Gossiper.getReleaseVersion(InetAddressAndPort ep) |
java.util.UUID |
Gossiper.getSchemaVersion(InetAddressAndPort ep) |
void |
Gossiper.initializeNodeUnsafe(InetAddressAndPort addr,
java.util.UUID uuid,
int generationNbr) |
void |
Gossiper.injectApplicationState(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
VersionedValue |
VersionedValue.VersionedValueFactory.internalAddressAndPort(InetAddressAndPort private_ip_and_port) |
void |
FailureDetector.interpret(InetAddressAndPort ep) |
void |
IFailureDetector.interpret(InetAddressAndPort ep)
This method is invoked by any entity wanting to interrogate the status of an endpoint.
|
boolean |
FailureDetector.isAlive(InetAddressAndPort ep) |
boolean |
Gossiper.isAlive(InetAddressAndPort endpoint) |
boolean |
IFailureDetector.isAlive(InetAddressAndPort ep)
Failure Detector's knowledge of whether a node is up or
down.
|
boolean |
Gossiper.isGossipOnlyMember(InetAddressAndPort endpoint) |
boolean |
Gossiper.isKnownEndpoint(InetAddressAndPort endpoint) |
boolean |
Gossiper.isSafeForStartup(InetAddressAndPort endpoint,
java.util.UUID localHostUUID,
boolean isBootstrapping,
java.util.Map<InetAddressAndPort,EndpointState> epStates)
Check if this node can safely be started and join the ring.
|
protected void |
Gossiper.markAsShutdown(InetAddressAndPort endpoint)
This method is used to mark a node as shutdown; that is it gracefully exited on its own and told us about it
|
void |
Gossiper.markDead(InetAddressAndPort addr,
EndpointState localState) |
protected void |
Gossiper.maybeFinishShadowRound(InetAddressAndPort respondent,
boolean isInShadowRound,
java.util.Map<InetAddressAndPort,EndpointState> epStateMap) |
VersionedValue |
VersionedValue.VersionedValueFactory.nativeaddressAndPort(InetAddressAndPort address) |
void |
IEndpointStateChangeSubscriber.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
IEndpointStateChangeSubscriber.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
IEndpointStateChangeSubscriber.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
IEndpointStateChangeSubscriber.onJoin(InetAddressAndPort endpoint,
EndpointState epState)
Use to inform interested parties about the change in the state
for specified endpoint
|
void |
IEndpointStateChangeSubscriber.onRemove(InetAddressAndPort endpoint) |
void |
IEndpointStateChangeSubscriber.onRestart(InetAddressAndPort endpoint,
EndpointState state)
Called whenever a node is restarted.
|
void |
Gossiper.realMarkAlive(InetAddressAndPort addr,
EndpointState localState) |
void |
FailureDetector.remove(InetAddressAndPort ep) |
void |
IFailureDetector.remove(InetAddressAndPort ep)
remove endpoint from failure detector
|
void |
Gossiper.removeEndpoint(InetAddressAndPort endpoint)
Removes the endpoint from Gossip but retains endpoint state
|
void |
Gossiper.replacedEndpoint(InetAddressAndPort endpoint)
Remove the Endpoint and evict immediately, to avoid gossiping about this node.
|
void |
Gossiper.replacementQuarantine(InetAddressAndPort endpoint)
Quarantine endpoint specifically for replacement purposes.
|
void |
FailureDetector.report(InetAddressAndPort ep) |
void |
IFailureDetector.report(InetAddressAndPort ep)
This method is invoked by the receiver of the heartbeat.
|
Modifier and Type | Method and Description |
---|---|
java.util.Map<InetAddressAndPort,EndpointState> |
Gossiper.doShadowRound(java.util.Set<InetAddressAndPort> peers)
Do a single 'shadow' round of gossip by retrieving endpoint states that will be stored exclusively in the
map return value, instead of endpointStateMap.
|
java.util.UUID |
Gossiper.getHostId(InetAddressAndPort endpoint,
java.util.Map<InetAddressAndPort,EndpointState> epStates) |
boolean |
Gossiper.isSafeForStartup(InetAddressAndPort endpoint,
java.util.UUID localHostUUID,
boolean isBootstrapping,
java.util.Map<InetAddressAndPort,EndpointState> epStates)
Check if this node can safely be started and join the ring.
|
protected void |
Gossiper.maybeFinishShadowRound(InetAddressAndPort respondent,
boolean isInShadowRound,
java.util.Map<InetAddressAndPort,EndpointState> epStateMap) |
Modifier and Type | Field and Description |
---|---|
protected java.util.Set<InetAddressAndPort> |
CqlBulkRecordWriter.ignores |
Modifier and Type | Method and Description |
---|---|
void |
HintsService.deleteAllHintsForEndpoint(InetAddressAndPort target)
Deletes all hints for the provided destination.
|
Modifier and Type | Method and Description |
---|---|
java.util.Map<InetAddressAndPort,java.util.Collection<Range<Token>>> |
SSTableLoader.Client.getEndpointToRangesMap() |
java.util.Set<InetAddressAndPort> |
SSTableLoader.getFailedHosts() |
Modifier and Type | Method and Description |
---|---|
protected void |
SSTableLoader.Client.addRangeForEndpoint(Range<Token> range,
InetAddressAndPort endpoint) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Collection<SSTableReader> |
SSTableLoader.openSSTables(java.util.Map<InetAddressAndPort,java.util.Collection<Range<Token>>> ranges) |
StreamResultFuture |
SSTableLoader.stream(java.util.Set<InetAddressAndPort> toIgnore,
StreamEventHandler... listeners) |
Modifier and Type | Method and Description |
---|---|
InetAddressAndPort |
InetAddressAndPort.Serializer.deserialize(DataInputPlus in,
int version) |
InetAddressAndPort |
RangesAtEndpoint.endpoint() |
InetAddressAndPort |
Replica.endpoint() |
InetAddressAndPort |
InetAddressAndPort.Serializer.extract(java.nio.ByteBuffer buf,
int position)
Extract
InetAddressAndPort from the provided ByteBuffer without altering its state. |
static InetAddressAndPort |
InetAddressAndPort.getByAddress(byte[] address) |
static InetAddressAndPort |
InetAddressAndPort.getByAddress(java.net.InetAddress address) |
static InetAddressAndPort |
InetAddressAndPort.getByAddressOverrideDefaults(java.net.InetAddress address,
byte[] addressBytes,
java.lang.Integer port) |
static InetAddressAndPort |
InetAddressAndPort.getByAddressOverrideDefaults(java.net.InetAddress address,
java.lang.Integer port) |
static InetAddressAndPort |
InetAddressAndPort.getByName(java.lang.String name) |
static InetAddressAndPort |
InetAddressAndPort.getByNameOverrideDefaults(java.lang.String name,
java.lang.Integer port) |
InetAddressAndPort |
TokenMetadata.getEndpoint(Token token) |
InetAddressAndPort |
TokenMetadata.getEndpointForHostId(java.util.UUID hostId)
Return the end-point for a unique host ID
|
static InetAddressAndPort |
InetAddressAndPort.getLocalHost() |
static InetAddressAndPort |
InetAddressAndPort.getLoopbackAddress() |
InetAddressAndPort |
InetAddressAndPort.withPort(int port) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<InetAddressAndPort,Replica> |
Endpoints.byEndpoint() |
java.util.List<InetAddressAndPort> |
Endpoints.endpointList() |
java.util.Set<InetAddressAndPort> |
Endpoints.endpoints() |
static java.util.function.Predicate<InetAddressAndPort> |
InOurDcTester.endpoints() |
java.util.Set<InetAddressAndPort> |
RangesAtEndpoint.endpoints() |
java.util.Set<InetAddressAndPort> |
ReplicaCollection.endpoints() |
static java.util.Collection<InetAddressAndPort> |
ReplicaPlans.filterBatchlogEndpoints(java.lang.String localRack,
com.google.common.collect.Multimap<java.lang.String,InetAddressAndPort> endpoints,
java.util.function.Consumer<java.util.List<?>> shuffle,
java.util.function.Predicate<InetAddressAndPort> isAlive,
java.util.function.Function<java.lang.Integer,java.lang.Integer> indexPicker) |
java.util.Set<InetAddressAndPort> |
TokenMetadata.getAllEndpoints() |
BiMultiValMap<Token,InetAddressAndPort> |
TokenMetadata.getBootstrapTokens() |
com.google.common.collect.Multimap<java.lang.String,InetAddressAndPort> |
TokenMetadata.Topology.getDatacenterEndpoints() |
com.google.common.collect.ImmutableMap<java.lang.String,com.google.common.collect.ImmutableMultimap<java.lang.String,InetAddressAndPort>> |
TokenMetadata.Topology.getDatacenterRacks() |
java.util.Map<InetAddressAndPort,java.util.UUID> |
TokenMetadata.getEndpointToHostIdMapForReading() |
com.google.common.collect.Multimap<InetAddressAndPort,Token> |
TokenMetadata.getEndpointToTokenMapForReading() |
java.util.Set<InetAddressAndPort> |
TokenMetadata.getLeavingEndpoints()
caller should not modify leavingEndpoints
|
java.util.Set<Pair<Token,InetAddressAndPort>> |
TokenMetadata.getMovingEndpoints()
Endpoints which are migrating to the new tokens
|
java.util.Map<Token,InetAddressAndPort> |
TokenMetadata.getNormalAndBootstrappingTokenToEndpointMap() |
java.util.Optional<InetAddressAndPort> |
TokenMetadata.getReplacementNode(InetAddressAndPort endpoint) |
java.util.Optional<InetAddressAndPort> |
TokenMetadata.getReplacingNode(InetAddressAndPort endpoint) |
java.util.List<InetAddressAndPort> |
SeedProvider.getSeeds() |
java.util.List<InetAddressAndPort> |
SimpleSeedProvider.getSeeds() |
Modifier and Type | Method and Description |
---|---|
void |
TokenMetadata.addBootstrapToken(Token token,
InetAddressAndPort endpoint)
Deprecated.
|
void |
TokenMetadata.addBootstrapTokens(java.util.Collection<Token> tokens,
InetAddressAndPort endpoint) |
void |
TokenMetadata.addLeavingEndpoint(InetAddressAndPort endpoint) |
void |
TokenMetadata.addMovingEndpoint(Token token,
InetAddressAndPort endpoint)
Add a new moving endpoint
|
void |
TokenMetadata.addReplaceTokens(java.util.Collection<Token> replacingTokens,
InetAddressAndPort newNode,
InetAddressAndPort oldNode) |
void |
ReconnectableSnitchHelper.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
static RangesAtEndpoint.Builder |
RangesAtEndpoint.builder(InetAddressAndPort endpoint) |
static RangesAtEndpoint.Builder |
RangesAtEndpoint.builder(InetAddressAndPort endpoint,
int capacity) |
static java.util.stream.Collector<Replica,RangesAtEndpoint.Builder,RangesAtEndpoint> |
RangesAtEndpoint.collector(InetAddressAndPort endpoint) |
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 would
|
int |
SimpleSnitch.compareEndpoints(InetAddressAndPort target,
Replica r1,
Replica r2) |
int |
InetAddressAndPort.compareTo(InetAddressAndPort o) |
static RangesAtEndpoint |
RangesAtEndpoint.empty(InetAddressAndPort endpoint) |
static Replica |
Replica.fullReplica(InetAddressAndPort endpoint,
Range<Token> range) |
static Replica |
Replica.fullReplica(InetAddressAndPort endpoint,
Token start,
Token end) |
RangesAtEndpoint |
RangesByEndpoint.get(InetAddressAndPort endpoint) |
RangesAtEndpoint |
AbstractReplicationStrategy.getAddressReplicas(InetAddressAndPort endpoint) |
RangesAtEndpoint |
AbstractReplicationStrategy.getAddressReplicas(TokenMetadata metadata,
InetAddressAndPort endpoint) |
abstract java.lang.String |
AbstractNetworkTopologySnitch.getDatacenter(InetAddressAndPort endpoint)
Return the data center for which an endpoint resides in
|
java.lang.String |
AlibabaCloudSnitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
CloudstackSnitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
DynamicEndpointSnitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
Ec2Snitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
GoogleCloudSnitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
GossipingPropertyFileSnitch.getDatacenter(InetAddressAndPort endpoint)
Return the data center for which an endpoint resides in
|
java.lang.String |
IEndpointSnitch.getDatacenter(InetAddressAndPort endpoint)
returns a String representing the datacenter the given endpoint belongs to
|
java.lang.String |
PropertyFileSnitch.getDatacenter(InetAddressAndPort endpoint)
Return the data center for which an endpoint resides in
|
java.lang.String |
RackInferringSnitch.getDatacenter(InetAddressAndPort endpoint) |
java.lang.String |
SimpleSnitch.getDatacenter(InetAddressAndPort endpoint) |
static java.lang.String[] |
PropertyFileSnitch.getEndpointInfo(InetAddressAndPort endpoint)
Get the raw information about an end point
|
java.util.UUID |
TokenMetadata.getHostId(InetAddressAndPort endpoint)
Return the unique host ID for an end-point.
|
Pair<java.lang.String,java.lang.String> |
TokenMetadata.Topology.getLocation(InetAddressAndPort addr) |
RangesAtEndpoint |
AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata,
java.util.Collection<Token> pendingTokens,
InetAddressAndPort pendingAddress) |
RangesAtEndpoint |
AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata,
Token pendingToken,
InetAddressAndPort pendingAddress) |
RangesAtEndpoint |
TokenMetadata.getPendingRanges(java.lang.String keyspaceName,
InetAddressAndPort endpoint) |
abstract java.lang.String |
AbstractNetworkTopologySnitch.getRack(InetAddressAndPort endpoint)
Return the rack for which an endpoint resides in
|
java.lang.String |
AlibabaCloudSnitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
CloudstackSnitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
DynamicEndpointSnitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
Ec2Snitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
GoogleCloudSnitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
GossipingPropertyFileSnitch.getRack(InetAddressAndPort endpoint)
Return the rack for which an endpoint resides in
|
java.lang.String |
IEndpointSnitch.getRack(InetAddressAndPort endpoint)
returns a String representing the rack the given endpoint belongs to
|
java.lang.String |
PropertyFileSnitch.getRack(InetAddressAndPort endpoint)
Return the rack for which an endpoint resides in
|
java.lang.String |
RackInferringSnitch.getRack(InetAddressAndPort endpoint) |
java.lang.String |
SimpleSnitch.getRack(InetAddressAndPort endpoint) |
java.util.Optional<InetAddressAndPort> |
TokenMetadata.getReplacementNode(InetAddressAndPort endpoint) |
java.util.Optional<InetAddressAndPort> |
TokenMetadata.getReplacingNode(InetAddressAndPort endpoint) |
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).
|
Token |
TokenMetadata.getToken(InetAddressAndPort endpoint)
Deprecated.
|
java.util.Collection<Token> |
TokenMetadata.getTokens(InetAddressAndPort endpoint) |
boolean |
TokenMetadata.isLeaving(InetAddressAndPort endpoint) |
boolean |
TokenMetadata.isMember(InetAddressAndPort endpoint) |
boolean |
TokenMetadata.isMoving(InetAddressAndPort endpoint) |
Replica |
ReplicaPlan.ForRead.lookup(InetAddressAndPort endpoint) |
Replica |
ReplicaPlan.ForWrite.lookup(InetAddressAndPort endpoint) |
protected RangesAtEndpoint.Builder |
RangesByEndpoint.Builder.newBuilder(InetAddressAndPort endpoint) |
void |
ReconnectableSnitchHelper.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
ReconnectableSnitchHelper.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
ReconnectableSnitchHelper.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
ReconnectableSnitchHelper.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
ReconnectableSnitchHelper.onRemove(InetAddressAndPort endpoint) |
void |
ReconnectableSnitchHelper.onRestart(InetAddressAndPort endpoint,
EndpointState state) |
int |
TokenMetadata.pendingRangeChanges(InetAddressAndPort source) |
void |
DynamicEndpointSnitch.receiveTiming(InetAddressAndPort host,
long latency,
java.util.concurrent.TimeUnit unit) |
void |
TokenMetadata.removeEndpoint(InetAddressAndPort endpoint) |
void |
TokenMetadata.removeFromMoving(InetAddressAndPort endpoint)
Remove pair of token/address from moving endpoints
|
void |
InetAddressAndPort.Serializer.serialize(InetAddressAndPort endpoint,
DataOutputPlus out,
int version) |
long |
InetAddressAndPort.Serializer.serializedSize(InetAddressAndPort from,
int version) |
<C extends ReplicaCollection<? extends C>> |
AbstractEndpointSnitch.sortedByProximity(InetAddressAndPort address,
C unsortedAddress)
Sorts the Collection of node addresses by proximity to the given address
|
<C extends ReplicaCollection<? extends C>> |
DynamicEndpointSnitch.sortedByProximity(InetAddressAndPort address,
C unsortedAddresses) |
<C extends ReplicaCollection<? extends C>> |
IEndpointSnitch.sortedByProximity(InetAddressAndPort address,
C addresses)
returns a new List sorted by proximity to the given endpoint
|
<C extends ReplicaCollection<? extends C>> |
SimpleSnitch.sortedByProximity(InetAddressAndPort address,
C unsortedAddress) |
static Replica |
Replica.transientReplica(InetAddressAndPort endpoint,
Range<Token> range) |
static Replica |
Replica.transientReplica(InetAddressAndPort endpoint,
Token start,
Token end) |
void |
TokenMetadata.updateHostId(java.util.UUID hostId,
InetAddressAndPort endpoint)
Store an end-point to host ID mapping.
|
void |
TokenMetadata.updateNormalToken(Token token,
InetAddressAndPort endpoint)
Update token map with a single token/endpoint pair in normal state.
|
void |
TokenMetadata.updateNormalTokens(java.util.Collection<Token> tokens,
InetAddressAndPort endpoint) |
TokenMetadata.Topology |
TokenMetadata.updateTopology(InetAddressAndPort endpoint)
This is called when the snitch properties for this endpoint are updated, see CASSANDRA-10238.
|
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<InetAddressAndPort> |
ReplicaPlans.filterBatchlogEndpoints(java.lang.String localRack,
com.google.common.collect.Multimap<java.lang.String,InetAddressAndPort> endpoints,
java.util.function.Consumer<java.util.List<?>> shuffle,
java.util.function.Predicate<InetAddressAndPort> isAlive,
java.util.function.Function<java.lang.Integer,java.lang.Integer> indexPicker) |
static java.util.Collection<InetAddressAndPort> |
ReplicaPlans.filterBatchlogEndpoints(java.lang.String localRack,
com.google.common.collect.Multimap<java.lang.String,InetAddressAndPort> endpoints,
java.util.function.Consumer<java.util.List<?>> shuffle,
java.util.function.Predicate<InetAddressAndPort> isAlive,
java.util.function.Function<java.lang.Integer,java.lang.Integer> indexPicker) |
static EndpointsForRange |
SystemReplicas.getSystemReplicas(java.util.Collection<InetAddressAndPort> endpoints) |
E |
Endpoints.keep(java.util.Set<InetAddressAndPort> keep) |
E |
Endpoints.select(java.lang.Iterable<InetAddressAndPort> endpoints,
boolean ignoreMissing) |
void |
TokenMetadata.updateNormalTokens(com.google.common.collect.Multimap<InetAddressAndPort,Token> endpointTokens)
Update token map with a set of token/endpoint pairs in normal state.
|
E |
Endpoints.without(java.util.Set<InetAddressAndPort> remove) |
Constructor and Description |
---|
Builder(InetAddressAndPort endpoint) |
Builder(InetAddressAndPort endpoint,
int capacity) |
Replica(InetAddressAndPort endpoint,
Range<Token> range,
boolean full) |
Replica(InetAddressAndPort endpoint,
Token start,
Token end,
boolean full) |
Constructor and Description |
---|
RangesByEndpoint(java.util.Map<InetAddressAndPort,RangesAtEndpoint> map) |
Modifier and Type | Method and Description |
---|---|
static StreamingMetrics |
StreamingMetrics.get(InetAddressAndPort ip) |
void |
HintedHandoffMetrics.incrCreatedHints(InetAddressAndPort address) |
void |
HintedHandoffMetrics.incrPastWindow(InetAddressAndPort address) |
MessagingMetrics.DCLatencyRecorder |
MessagingMetrics.internodeLatencyRecorder(InetAddressAndPort from) |
static void |
HintsServiceMetrics.updateDelayMetrics(InetAddressAndPort endpoint,
long delay) |
Constructor and Description |
---|
DifferencingCounter(InetAddressAndPort address) |
InternodeInboundMetrics(InetAddressAndPort peer,
InboundMessageHandlers handlers)
Create metrics for given inbound message handlers.
|
InternodeOutboundMetrics(InetAddressAndPort ip,
OutboundConnections messagingPool)
Create metrics for given connection pool.
|
StreamingMetrics(InetAddressAndPort peer) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
InboundConnectionSettings.bindAddress |
InetAddressAndPort |
OutboundConnectionSettings.connectTo |
InetAddressAndPort |
Message.Header.from |
InetAddressAndPort |
OutboundConnectionSettings.from |
InetAddressAndPort |
OutboundConnectionSettings.to |
Modifier and Type | Field and Description |
---|---|
java.util.concurrent.ConcurrentMap<InetAddressAndPort,OutboundConnections> |
MessagingServiceMBeanImpl.channelManagers |
java.util.function.Function<InetAddressAndPort,InboundMessageHandlers> |
InboundConnectionSettings.handlers |
java.util.concurrent.ConcurrentMap<InetAddressAndPort,InboundMessageHandlers> |
MessagingServiceMBeanImpl.messageHandlers |
Modifier and Type | Method and Description |
---|---|
InetAddressAndPort |
OutboundConnectionSettings.connectTo() |
InetAddressAndPort |
Message.from()
Sender of the message.
|
InetAddressAndPort |
OutboundConnectionSettings.from() |
InetAddressAndPort |
Message.respondTo()
The originator of the request - used when forwarding and will differ from
Message.from() |
Modifier and Type | Method and Description |
---|---|
void |
OutboundSink.accept(Message<?> message,
InetAddressAndPort to,
ConnectionType connectionType) |
void |
OutboundSink.Sink.accept(Message<?> message,
InetAddressAndPort to,
ConnectionType connectionType) |
void |
LatencySubscribers.add(InetAddressAndPort address,
long latency,
java.util.concurrent.TimeUnit unit) |
boolean |
InboundConnectionSettings.authenticate(InetAddressAndPort endpoint) |
void |
MessagingService.closeOutbound(InetAddressAndPort to)
Only to be invoked once we believe the endpoint will never be contacted again.
|
<T> Message<T> |
Message.Serializer.deserialize(DataInputPlus in,
InetAddressAndPort peer,
int version) |
Message.Builder<T> |
Message.Builder.from(InetAddressAndPort from) |
int |
EndpointMessagingVersions.get(InetAddressAndPort endpoint)
Returns the messaging-version as announced by the given node but capped
to the min of the version as announced by the node and
MessagingService.current_version . |
int |
EndpointMessagingVersions.getRaw(InetAddressAndPort endpoint)
Returns the messaging-version exactly as announced by the given endpoint.
|
LatencyConsumer |
InboundMessageHandlers.GlobalMetricCallbacks.internodeLatencyRecorder(InetAddressAndPort to) |
void |
MessagingService.interruptOutbound(InetAddressAndPort to)
Closes any current open channel/connection to the endpoint, but does not cause any message loss, and we will
try to re-establish connections immediately
|
boolean |
EndpointMessagingVersions.knows(InetAddressAndPort endpoint) |
void |
LatencySubscribers.maybeAdd(RequestCallback cb,
InetAddressAndPort address,
long latency,
java.util.concurrent.TimeUnit unit)
Track latency information for the dynamic snitch
|
io.netty.util.concurrent.Future<java.lang.Void> |
MessagingService.maybeReconnectWithNewIp(InetAddressAndPort address,
InetAddressAndPort preferredAddress)
Reconnect to the peer using the given
addr . |
void |
RequestCallbacks.onDiscardOnClose(Message<?> message,
InetAddressAndPort peer) |
void |
RequestCallbacks.onExpired(Message<?> message,
InetAddressAndPort peer) |
void |
RequestCallbacks.onFailedSerialize(Message<?> message,
InetAddressAndPort peer,
int messagingVersion,
int bytesWrittenToNetwork,
java.lang.Throwable failure) |
default void |
RequestCallback.onFailure(InetAddressAndPort from,
RequestFailureReason failureReason)
Called when there is an exception on the remote node or timeout happens
|
void |
RequestCallbacks.onOverloaded(Message<?> message,
InetAddressAndPort peer) |
void |
LatencySubscribers.Subscriber.receiveTiming(InetAddressAndPort address,
long latency,
java.util.concurrent.TimeUnit unit) |
void |
RequestCallbacks.removeAndRespond(long id,
InetAddressAndPort peer,
Message message) |
void |
MessagingService.removeInbound(InetAddressAndPort from)
Only to be invoked once we believe the connections will never be used again.
|
void |
EndpointMessagingVersions.reset(InetAddressAndPort endpoint) |
void |
MessagingService.send(Message message,
InetAddressAndPort to)
Send a message to a given endpoint.
|
void |
MessagingService.send(Message message,
InetAddressAndPort to,
ConnectionType specifyConnection) |
void |
MessagingService.sendWithCallback(Message message,
InetAddressAndPort to,
RequestCallback cb)
Send a non-mutation message to a given endpoint.
|
void |
MessagingService.sendWithCallback(Message message,
InetAddressAndPort to,
RequestCallback cb,
ConnectionType specifyConnection) |
int |
EndpointMessagingVersions.set(InetAddressAndPort endpoint,
int version) |
OutboundConnectionSettings |
OutboundConnectionSettings.toEndpoint(InetAddressAndPort endpoint) |
InboundConnectionSettings |
InboundConnectionSettings.withBindAddress(InetAddressAndPort bindAddress) |
OutboundConnectionSettings |
OutboundConnectionSettings.withConnectTo(InetAddressAndPort connectTo) |
OutboundConnectionSettings |
OutboundConnectionSettings.withFrom(InetAddressAndPort from) |
Modifier and Type | Method and Description |
---|---|
void |
OutboundSink.add(java.util.function.BiPredicate<Message<?>,InetAddressAndPort> allow) |
boolean |
StartupClusterConnectivityChecker.execute(java.util.Set<InetAddressAndPort> peers,
java.util.function.Function<InetAddressAndPort,java.lang.String> getDatacenterSource) |
boolean |
StartupClusterConnectivityChecker.execute(java.util.Set<InetAddressAndPort> peers,
java.util.function.Function<InetAddressAndPort,java.lang.String> getDatacenterSource) |
void |
ForwardingInfo.forEach(java.util.function.BiConsumer<java.lang.Long,InetAddressAndPort> biConsumer)
Apply the provided consumer to all (host, message_id) pairs.
|
void |
OutboundSink.remove(java.util.function.BiPredicate<Message<?>,InetAddressAndPort> allow) |
InboundConnectionSettings |
InboundConnectionSettings.withHandlers(java.util.function.Function<InetAddressAndPort,InboundMessageHandlers> handlers) |
Constructor and Description |
---|
InboundMessageHandlers(InetAddressAndPort self,
InetAddressAndPort peer,
int queueCapacity,
long endpointReserveCapacity,
org.apache.cassandra.net.InboundMessageHandlers.GlobalResourceLimits globalResourceLimits,
InboundMessageHandlers.GlobalMetricCallbacks globalMetricCallbacks,
InboundMessageHandlers.MessageConsumer messageConsumer) |
InboundMessageHandlers(InetAddressAndPort self,
InetAddressAndPort peer,
int queueCapacity,
long endpointReserveCapacity,
org.apache.cassandra.net.InboundMessageHandlers.GlobalResourceLimits globalResourceLimits,
InboundMessageHandlers.GlobalMetricCallbacks globalMetricCallbacks,
InboundMessageHandlers.MessageConsumer messageConsumer,
org.apache.cassandra.net.InboundMessageHandlers.HandlerProvider handlerProvider) |
OutboundConnectionSettings(InetAddressAndPort to) |
OutboundConnectionSettings(InetAddressAndPort to,
InetAddressAndPort preferred) |
Constructor and Description |
---|
ForwardingInfo(java.util.List<InetAddressAndPort> targets,
long[] messageIds) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
SyncNodePair.coordinator |
InetAddressAndPort |
TreeResponse.endpoint |
InetAddressAndPort |
Validator.initiator |
InetAddressAndPort |
SyncNodePair.peer |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.ImmutableSet<InetAddressAndPort> |
CommonRange.endpoints |
com.google.common.collect.ImmutableSet<InetAddressAndPort> |
CommonRange.transEndpoints |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<InetAddressAndPort> |
RepairSession.endpoints() |
Modifier and Type | Method and Description |
---|---|
void |
RepairSession.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
void |
RepairSession.convict(InetAddressAndPort endpoint,
double phi) |
void |
RepairSession.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
RepairSession.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
RepairSession.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
RepairSession.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
RepairSession.onRemove(InetAddressAndPort endpoint) |
void |
RepairSession.onRestart(InetAddressAndPort endpoint,
EndpointState epState) |
void |
RepairSession.validationComplete(RepairJobDesc desc,
InetAddressAndPort endpoint,
MerkleTrees trees)
Receive merkle tree response or failed response from
endpoint for current repair job. |
Modifier and Type | Method and Description |
---|---|
boolean |
CommonRange.matchesEndpoints(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints) |
boolean |
CommonRange.matchesEndpoints(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints) |
void |
RepairSession.trackValidationCompletion(Pair<RepairJobDesc,InetAddressAndPort> key,
ValidationTask task) |
Constructor and Description |
---|
AsymmetricRemoteSyncTask(RepairJobDesc desc,
InetAddressAndPort to,
InetAddressAndPort from,
java.util.List<Range<Token>> differences,
PreviewKind previewKind) |
LocalSyncTask(RepairJobDesc desc,
InetAddressAndPort local,
InetAddressAndPort remote,
java.util.List<Range<Token>> diff,
java.util.UUID pendingRepair,
boolean requestRanges,
boolean transferRanges,
PreviewKind previewKind) |
StreamingRepairTask(RepairJobDesc desc,
InetAddressAndPort initiator,
InetAddressAndPort src,
InetAddressAndPort dst,
java.util.Collection<Range<Token>> ranges,
java.util.UUID pendingRepair,
PreviewKind previewKind,
boolean asymmetric) |
SymmetricRemoteSyncTask(RepairJobDesc desc,
InetAddressAndPort r1,
InetAddressAndPort r2,
java.util.List<Range<Token>> differences,
PreviewKind previewKind) |
SyncNodePair(InetAddressAndPort coordinator,
InetAddressAndPort peer) |
SyncTask(RepairJobDesc desc,
InetAddressAndPort primaryEndpoint,
InetAddressAndPort peer,
java.util.List<Range<Token>> rangesToSync,
PreviewKind previewKind) |
TreeResponse(InetAddressAndPort endpoint,
MerkleTrees trees) |
ValidationTask(RepairJobDesc desc,
InetAddressAndPort endpoint,
int nowInSec,
PreviewKind previewKind) |
Validator(RepairJobDesc desc,
InetAddressAndPort initiator,
int nowInSec,
boolean evenTreeDistribution,
boolean isIncremental,
PreviewKind previewKind) |
Validator(RepairJobDesc desc,
InetAddressAndPort initiator,
int nowInSec,
boolean isIncremental,
PreviewKind previewKind) |
Validator(RepairJobDesc desc,
InetAddressAndPort initiator,
int nowInSec,
PreviewKind previewKind) |
Constructor and Description |
---|
CommonRange(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints,
java.util.Collection<Range<Token>> ranges) |
CommonRange(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints,
java.util.Collection<Range<Token>> ranges) |
Modifier and Type | Method and Description |
---|---|
java.lang.Iterable<java.util.Set<InetAddressAndPort>> |
StreamFromOptions.allStreams() |
java.util.Set<InetAddressAndPort> |
PreferedNodeFilter.apply(InetAddressAndPort streamingNode,
java.util.Set<InetAddressAndPort> toStream) |
java.util.Set<InetAddressAndPort> |
HostDifferences.hosts() |
java.util.Set<InetAddressAndPort> |
DifferenceHolder.keyHosts()
differences only holds one 'side' of the difference - if A and B mismatch, only A will be a key in the map
|
static com.google.common.collect.ImmutableMap<InetAddressAndPort,HostDifferences> |
ReduceHelper.reduce(DifferenceHolder differences,
PreferedNodeFilter filter)
Reduces the differences provided by the merkle trees to a minimum set of differences
|
Modifier and Type | Method and Description |
---|---|
void |
StreamFromOptions.add(InetAddressAndPort streamFromNode)
Add new node to the stream options
If we have no difference between the new node and a currently tracked on, we know they are matching over the
range we are tracking, then just add it to the set with the identical remote nodes.
|
void |
HostDifferences.add(InetAddressAndPort endpoint,
java.util.List<Range<Token>> difference)
Adds a set of differences between the node this instance is tracking and endpoint
|
void |
IncomingRepairStreamTracker.addIncomingRangeFrom(Range<Token> range,
InetAddressAndPort streamFromNode)
Adds a range to be streamed from streamFromNode
First the currently tracked ranges are denormalized to make sure that no ranges overlap, then
the streamFromNode is added to the StreamFromOptions for the range
|
void |
HostDifferences.addSingleRange(InetAddressAndPort remoteNode,
Range<Token> rangeToFetch) |
java.util.Set<InetAddressAndPort> |
PreferedNodeFilter.apply(InetAddressAndPort streamingNode,
java.util.Set<InetAddressAndPort> toStream) |
HostDifferences |
DifferenceHolder.get(InetAddressAndPort hostWithDifference) |
java.util.List<Range<Token>> |
HostDifferences.get(InetAddressAndPort differingHost) |
boolean |
DifferenceHolder.hasDifferenceBetween(InetAddressAndPort node1,
InetAddressAndPort node2,
Range<Token> range) |
boolean |
HostDifferences.hasDifferencesFor(InetAddressAndPort node2,
Range<Token> range)
Does this instance have differences for range with node2?
|
Modifier and Type | Method and Description |
---|---|
java.util.Set<InetAddressAndPort> |
PreferedNodeFilter.apply(InetAddressAndPort streamingNode,
java.util.Set<InetAddressAndPort> toStream) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
ConsistentSession.coordinator |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.ImmutableSet<InetAddressAndPort> |
ConsistentSession.participants |
Modifier and Type | Method and Description |
---|---|
protected InetAddressAndPort |
LocalSessions.getBroadcastAddressAndPort() |
Modifier and Type | Method and Description |
---|---|
void |
LocalSessions.handleFailSessionMessage(InetAddressAndPort from,
FailSession msg) |
void |
LocalSessions.handleFinalizeCommitMessage(InetAddressAndPort from,
FinalizeCommit commit)
Finalizes the repair session, completing it as successful.
|
void |
CoordinatorSession.handleFinalizePromise(InetAddressAndPort participant,
boolean success) |
void |
LocalSessions.handleFinalizeProposeMessage(InetAddressAndPort from,
FinalizePropose propose) |
void |
LocalSessions.handlePrepareMessage(InetAddressAndPort from,
PrepareConsistentRequest request)
The PrepareConsistentRequest promotes the parent repair session to a consistent incremental
session, and isolates the data to be repaired from the rest of the table's data
No response is sent to the repair coordinator until the data preparation / isolation has completed
successfully.
|
void |
CoordinatorSession.handlePrepareResponse(InetAddressAndPort participant,
boolean success) |
void |
LocalSessions.handleStatusRequest(InetAddressAndPort from,
StatusRequest request) |
void |
LocalSessions.handleStatusResponse(InetAddressAndPort from,
StatusResponse response) |
protected boolean |
LocalSessions.isAlive(InetAddressAndPort address) |
protected void |
LocalSessions.sendMessage(InetAddressAndPort destination,
Message<? extends RepairMessage> message) |
protected void |
CoordinatorSession.sendMessage(InetAddressAndPort destination,
Message<RepairMessage> message) |
void |
CoordinatorSession.setParticipantState(InetAddressAndPort participant,
ConsistentSession.State state) |
Modifier and Type | Method and Description |
---|---|
CoordinatorSession |
CoordinatorSessions.registerSession(java.util.UUID sessionId,
java.util.Set<InetAddressAndPort> participants,
boolean isForced) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
PrepareConsistentRequest.coordinator |
InetAddressAndPort |
SyncRequest.dst |
InetAddressAndPort |
AsymmetricSyncRequest.fetchFrom |
InetAddressAndPort |
AsymmetricSyncRequest.fetchingNode |
InetAddressAndPort |
AsymmetricSyncRequest.initiator |
InetAddressAndPort |
SyncRequest.initiator |
InetAddressAndPort |
FinalizePromise.participant |
InetAddressAndPort |
PrepareConsistentResponse.participant |
InetAddressAndPort |
SyncRequest.src |
Modifier and Type | Field and Description |
---|---|
java.util.Set<InetAddressAndPort> |
PrepareConsistentRequest.participants |
Constructor and Description |
---|
AsymmetricSyncRequest(RepairJobDesc desc,
InetAddressAndPort initiator,
InetAddressAndPort fetchingNode,
InetAddressAndPort fetchFrom,
java.util.Collection<Range<Token>> ranges,
PreviewKind previewKind) |
FinalizePromise(java.util.UUID sessionID,
InetAddressAndPort participant,
boolean promised) |
PrepareConsistentRequest(java.util.UUID parentSession,
InetAddressAndPort coordinator,
java.util.Set<InetAddressAndPort> participants) |
PrepareConsistentResponse(java.util.UUID parentSession,
InetAddressAndPort participant,
boolean success) |
SyncRequest(RepairJobDesc desc,
InetAddressAndPort initiator,
InetAddressAndPort src,
InetAddressAndPort dst,
java.util.Collection<Range<Token>> ranges,
PreviewKind previewKind) |
SyncResponse(RepairJobDesc desc,
InetAddressAndPort endpoint1,
InetAddressAndPort endpoint2,
boolean success,
java.util.List<SessionSummary> summaries) |
Constructor and Description |
---|
PrepareConsistentRequest(java.util.UUID parentSession,
InetAddressAndPort coordinator,
java.util.Set<InetAddressAndPort> participants) |
Modifier and Type | Method and Description |
---|---|
static void |
MigrationManager.scheduleSchemaPull(InetAddressAndPort endpoint,
EndpointState state) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
ActiveRepairService.ParentRepairSession.coordinator |
InetAddressAndPort |
TokenRange.EndpointDetails.host |
Modifier and Type | Method and Description |
---|---|
InetAddressAndPort |
StorageService.getEndpointForHostId(java.util.UUID hostId) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<InetAddressAndPort> |
StorageService.getLiveRingMembers() |
java.util.Set<InetAddressAndPort> |
StorageService.getLiveRingMembers(boolean excludeDeadStates) |
java.util.Map<InetAddressAndPort,java.lang.Double> |
LoadBroadcaster.getLoadInfo() |
Modifier and Type | Method and Description |
---|---|
protected void |
StorageService.addExpireTimeIfFound(InetAddressAndPort endpoint,
long expireTime) |
void |
ActiveRepairService.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
void |
LoadBroadcaster.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
void |
StorageService.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
void |
StorageService.confirmReplication(InetAddressAndPort node) |
void |
ActiveRepairService.convict(InetAddressAndPort ep,
double phi)
Something has happened to a remote node - if that node is a coordinator, we mark the parent repair session id as failed.
|
java.util.UUID |
StorageService.getHostIdForEndpoint(InetAddressAndPort address) |
java.util.Collection<Range<Token>> |
StorageService.getLocalPrimaryRangeForEndpoint(InetAddressAndPort referenceEndpoint) |
java.lang.String |
StorageService.getNativeaddress(InetAddressAndPort endpoint,
boolean withPort)
Return the native address associated with an endpoint as a string.
|
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangeForEndpointWithinDC(java.lang.String keyspace,
InetAddressAndPort referenceEndpoint)
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangesForEndpoint(java.lang.String keyspace,
InetAddressAndPort ep)
Get the "primary ranges" for the specified keyspace and endpoint.
|
boolean |
StorageService.isRpcReady(InetAddressAndPort endpoint) |
void |
ActiveRepairService.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
LoadBroadcaster.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
StorageService.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
ActiveRepairService.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
LoadBroadcaster.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
StorageService.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
ActiveRepairService.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
LoadBroadcaster.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
StorageService.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
IEndpointLifecycleSubscriber.onDown(InetAddressAndPort endpoint)
Called when a node is marked DOWN.
|
void |
AbstractWriteResponseHandler.onFailure(InetAddressAndPort from,
RequestFailureReason failureReason) |
void |
BatchlogResponseHandler.onFailure(InetAddressAndPort from,
RequestFailureReason failureReason) |
void |
ActiveRepairService.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
LoadBroadcaster.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
StorageService.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
IEndpointLifecycleSubscriber.onJoinCluster(InetAddressAndPort endpoint)
Called when a new node joins the cluster, i.e.
|
void |
IEndpointLifecycleSubscriber.onLeaveCluster(InetAddressAndPort endpoint)
Called when a new node leave the cluster (decommission or removeToken).
|
void |
IEndpointLifecycleSubscriber.onMove(InetAddressAndPort endpoint)
Called when a node has moved (to a new token).
|
void |
ActiveRepairService.onRemove(InetAddressAndPort endpoint) |
void |
LoadBroadcaster.onRemove(InetAddressAndPort endpoint) |
void |
StorageService.onRemove(InetAddressAndPort endpoint) |
void |
ActiveRepairService.onRestart(InetAddressAndPort endpoint,
EndpointState state) |
void |
LoadBroadcaster.onRestart(InetAddressAndPort endpoint,
EndpointState state) |
void |
StorageService.onRestart(InetAddressAndPort endpoint,
EndpointState state) |
void |
IEndpointLifecycleSubscriber.onUp(InetAddressAndPort endpoint)
Called when a node is marked UP.
|
java.util.UUID |
ActiveRepairService.prepareForRepair(java.util.UUID parentRepairSession,
InetAddressAndPort coordinator,
java.util.Set<InetAddressAndPort> endpoints,
RepairOption options,
boolean isForcedRepair,
java.util.List<ColumnFamilyStore> columnFamilyStores) |
void |
ActiveRepairService.registerParentRepairSession(java.util.UUID parentRepairSession,
InetAddressAndPort coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long repairedAt,
boolean isGlobal,
PreviewKind previewKind) |
void |
StorageService.updateTopology(InetAddressAndPort endpoint) |
protected boolean |
AbstractWriteResponseHandler.waitingFor(InetAddressAndPort from) |
protected boolean |
BatchlogResponseHandler.waitingFor(InetAddressAndPort from) |
protected boolean |
DatacenterWriteResponseHandler.waitingFor(InetAddressAndPort from) |
Modifier and Type | Method and Description |
---|---|
static TokenRange |
TokenRange.create(Token.TokenFactory tokenFactory,
Range<Token> range,
java.util.List<InetAddressAndPort> endpoints,
boolean withPorts) |
java.util.UUID |
ActiveRepairService.prepareForRepair(java.util.UUID parentRepairSession,
InetAddressAndPort coordinator,
java.util.Set<InetAddressAndPort> endpoints,
RepairOption options,
boolean isForcedRepair,
java.util.List<ColumnFamilyStore> columnFamilyStores) |
Constructor and Description |
---|
ParentRepairSession(InetAddressAndPort coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long repairedAt,
boolean isGlobal,
PreviewKind previewKind) |
Modifier and Type | Method and Description |
---|---|
java.lang.Iterable<InetAddressAndPort> |
PrepareCallback.replicasMissingMostRecentCommit(TableMetadata metadata,
int nowInSec) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
DigestResolver.DigestResolverDebugResult.from |
Modifier and Type | Method and Description |
---|---|
void |
ReadCallback.onFailure(InetAddressAndPort from,
RequestFailureReason failureReason) |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.Multimap<java.nio.ByteBuffer,InetAddressAndPort> |
RepairedDataTracker.digests |
java.util.Set<InetAddressAndPort> |
RepairedDataTracker.inconclusiveDigests |
Modifier and Type | Method and Description |
---|---|
static Mutation |
BlockingReadRepairs.createRepairMutation(PartitionUpdate update,
ConsistencyLevel consistency,
InetAddressAndPort destination,
boolean suppressException)
Create a read repair mutation from the given update, if the mutation is not larger than the maximum
mutation size, otherwise return null.
|
void |
RepairedDataTracker.recordDigest(InetAddressAndPort source,
java.nio.ByteBuffer digest,
boolean isConclusive) |
protected void |
BlockingPartitionRepair.sendRR(Message<Mutation> message,
InetAddressAndPort endpoint) |
Constructor and Description |
---|
BlockingPartitionRepair(DecoratedKey key,
java.util.Map<Replica,Mutation> repairs,
ReplicaPlan.ForTokenWrite writePlan,
java.util.function.Predicate<InetAddressAndPort> shouldBlockOn) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
SessionInfo.connecting |
InetAddressAndPort |
SessionSummary.coordinator |
InetAddressAndPort |
ProgressInfo.peer |
InetAddressAndPort |
SessionInfo.peer |
InetAddressAndPort |
SessionSummary.peer |
InetAddressAndPort |
StreamEvent.SessionCompleteEvent.peer |
InetAddressAndPort |
StreamSession.peer
Streaming endpoint.
|
Modifier and Type | Method and Description |
---|---|
java.util.Set<InetAddressAndPort> |
StreamCoordinator.getPeers() |
Modifier and Type | Method and Description |
---|---|
void |
StreamSession.beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
static StreamResultFuture |
StreamResultFuture.createFollower(int sessionIndex,
java.util.UUID planId,
StreamOperation streamOperation,
InetAddressAndPort from,
io.netty.channel.Channel channel,
java.util.UUID pendingRepair,
PreviewKind previewKind) |
StreamSession |
StreamManager.findSession(InetAddressAndPort peer,
java.util.UUID planId,
int sessionIndex,
boolean searchInitiatorSessions) |
StreamSession |
StreamCoordinator.getOrCreateNextSession(InetAddressAndPort peer) |
StreamSession |
StreamCoordinator.getOrCreateSessionById(InetAddressAndPort peer,
int id) |
static StreamManager.StreamRateLimiter |
StreamManager.getRateLimiter(InetAddressAndPort peer)
Gets streaming rate limiter.
|
StreamSession |
StreamResultFuture.getSession(InetAddressAndPort peer,
int sessionIndex) |
StreamSession |
StreamCoordinator.getSessionById(InetAddressAndPort peer,
int id) |
void |
StreamSession.onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
StreamSession.onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
StreamSession.MessageStateSink.onClose(InetAddressAndPort from) |
void |
StreamSession.onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
StreamSession.onJoin(InetAddressAndPort endpoint,
EndpointState epState) |
void |
StreamSession.onRemove(InetAddressAndPort endpoint) |
void |
StreamSession.onRestart(InetAddressAndPort endpoint,
EndpointState epState) |
void |
StreamSession.MessageStateSink.recordMessage(InetAddressAndPort from,
StreamMessage.Type message) |
void |
StreamSession.MessageStateSink.recordState(InetAddressAndPort from,
StreamSession.State state) |
StreamPlan |
StreamPlan.requestRanges(InetAddressAndPort from,
java.lang.String keyspace,
RangesAtEndpoint fullRanges,
RangesAtEndpoint transientRanges)
Request data in
keyspace and ranges from specific node. |
StreamPlan |
StreamPlan.requestRanges(InetAddressAndPort from,
java.lang.String keyspace,
RangesAtEndpoint fullRanges,
RangesAtEndpoint transientRanges,
java.lang.String... columnFamilies)
Request data in
columnFamilies under keyspace and ranges from specific node. |
StreamPlan |
StreamPlan.transferRanges(InetAddressAndPort to,
java.lang.String keyspace,
RangesAtEndpoint replicas,
java.lang.String... columnFamilies)
Add transfer task to send data of specific
columnFamilies under keyspace and ranges . |
void |
StreamCoordinator.transferStreams(InetAddressAndPort to,
java.util.Collection<OutgoingStream> streams) |
StreamPlan |
StreamPlan.transferStreams(InetAddressAndPort to,
java.util.Collection<OutgoingStream> streams)
Add transfer task to send given streams
|
Constructor and Description |
---|
ProgressInfo(InetAddressAndPort peer,
int sessionIndex,
java.lang.String fileName,
ProgressInfo.Direction direction,
long currentBytes,
long totalBytes) |
SessionInfo(InetAddressAndPort peer,
int sessionIndex,
InetAddressAndPort connecting,
java.util.Collection<StreamSummary> receivingSummaries,
java.util.Collection<StreamSummary> sendingSummaries,
StreamSession.State state) |
SessionSummary(InetAddressAndPort coordinator,
InetAddressAndPort peer,
java.util.Collection<StreamSummary> receivingSummaries,
java.util.Collection<StreamSummary> sendingSummaries) |
StreamRateLimiter(InetAddressAndPort peer) |
StreamSession(StreamOperation streamOperation,
InetAddressAndPort peer,
StreamConnectionFactory factory,
boolean isFollower,
int index,
java.util.UUID pendingRepair,
PreviewKind previewKind)
Create new streaming session with the peer.
|
Constructor and Description |
---|
StreamingInboundHandler(InetAddressAndPort remoteAddress,
int protocolVersion,
StreamSession session) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
StreamInitMessage.from |
InetAddressAndPort |
StreamMessageHeader.sender |
Constructor and Description |
---|
StreamInitMessage(InetAddressAndPort from,
int sessionIndex,
java.util.UUID planId,
StreamOperation streamOperation,
java.util.UUID pendingRepair,
PreviewKind previewKind) |
StreamMessageHeader(TableId tableId,
InetAddressAndPort sender,
java.util.UUID planId,
boolean sendByFollower,
int sessionIndex,
int sequenceNumber,
long repairedAt,
java.util.UUID pendingRepair) |
Modifier and Type | Field and Description |
---|---|
java.util.Set<InetAddressAndPort> |
LoaderOptions.ignores |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
HostStatWithPort.endpointWithPort |
Constructor and Description |
---|
HostStatWithPort(java.lang.String token,
InetAddressAndPort endpoint,
boolean resolveIp,
java.lang.Float owns) |
Modifier and Type | Field and Description |
---|---|
InetAddressAndPort |
TraceState.coordinator |
Modifier and Type | Method and Description |
---|---|
protected abstract TraceState |
Tracing.newTraceState(InetAddressAndPort coordinator,
java.util.UUID sessionId,
Tracing.TraceType traceType) |
void |
Tracing.traceOutgoingMessage(Message<?> message,
int serializedSize,
InetAddressAndPort sendTo)
Record any tracing data, if enabled on this message.
|
Constructor and Description |
---|
TraceState(InetAddressAndPort coordinator,
java.util.UUID sessionId,
Tracing.TraceType traceType) |
TraceStateImpl(InetAddressAndPort coordinator,
java.util.UUID sessionId,
Tracing.TraceType traceType) |
Modifier and Type | Method and Description |
---|---|
InetAddressAndPort |
Event.NodeEvent.nodeAddressAndPort() |
Modifier and Type | Method and Description |
---|---|
static Event.TopologyChange |
Event.TopologyChange.movedNode(InetAddressAndPort address) |
static Event.TopologyChange |
Event.TopologyChange.newNode(InetAddressAndPort address) |
static Event.StatusChange |
Event.StatusChange.nodeDown(InetAddressAndPort address) |
static Event.StatusChange |
Event.StatusChange.nodeUp(InetAddressAndPort address) |
static Event.TopologyChange |
Event.TopologyChange.removedNode(InetAddressAndPort address) |
Modifier and Type | Method and Description |
---|---|
static InetAddressAndPort |
FBUtilities.getBroadcastAddressAndPort()
Get the broadcast address and port for intra-cluster storage traffic.
|
static InetAddressAndPort |
FBUtilities.getBroadcastNativeAddressAndPort()
This returns the address that is bound to for the native protocol for communicating with clients.
|
static InetAddressAndPort |
FBUtilities.getLocalAddressAndPort()
The address and port to listen on for intra-cluster storage traffic (not client).
|
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<InetAddressAndPort> |
UUIDGen.getAllLocalAddresses()
Helper function used exclusively by UUIDGen to create
|
Modifier and Type | Method and Description |
---|---|
static void |
FBUtilities.setBroadcastInetAddressAndPort(InetAddressAndPort addr)
THIS IS FOR TESTING ONLY!!
|
static void |
DiagnosticSnapshotService.snapshot(SnapshotCommand command,
InetAddressAndPort initiator) |
Modifier and Type | Method and Description |
---|---|
static void |
DiagnosticSnapshotService.duplicateRows(TableMetadata metadata,
java.lang.Iterable<InetAddressAndPort> replicas) |
static void |
DiagnosticSnapshotService.repairedDataMismatch(TableMetadata metadata,
java.lang.Iterable<InetAddressAndPort> replicas) |
Copyright © 2009-2020 The Apache Software Foundation