|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private createServer(memberId MemberId) : RaftServer in class io.atomix.protocols.raft.RaftTest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Change Parameter Type primary : NodeId to primary : MemberId in method private requestRestore(primary MemberId) : void in class io.atomix.protocols.backup.roles.BackupRole |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestPrimaryBackupClientProtocol> to clients : Map<MemberId,TestPrimaryBackupClientProtocol> in method public TestPrimaryBackupClientProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public resetAll(leader MemberId, members Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.MemberSelectorManager |
From |
To |
|
Change Parameter Type node : ReplicatedNode to node : ReplicatedMember in method package NodeUpdate(node ReplicatedMember, timestamp LogicalTimestamp) in class io.atomix.cluster.impl.NodeUpdate |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public setLeader(leader MemberId) : void in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Change Parameter Type node : NodeId to node : MemberId in method public ExecuteOperation(index long, timestamp long, session long, node MemberId, operation PrimitiveOperation) in class io.atomix.protocols.backup.protocol.ExecuteOperation |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public join(cluster MemberId...) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public addListener(clusterMembershipService ClusterMembershipService, events EventManager) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected createAtomix(type Member.Type, id int, persistentIds List<Integer>, ephemeralIds List<Integer>, builderFunction Function<Atomix.Builder,Atomix>) : Atomix in class io.atomix.core.AbstractAtomixTest |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method protected Builder(cluster Collection<MemberId>) in class io.atomix.protocols.raft.RaftClient.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftFuzzTest.TestMember |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestRaftClientProtocol> to clients : Map<MemberId,TestRaftClientProtocol> in method public TestRaftProtocol(servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftProtocol |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public withMembers(members Collection<MemberId>) : Builder in class io.atomix.protocols.raft.protocol.KeepAliveResponse.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public NodeEvent(memberId MemberId, type Type) in class io.atomix.rest.resources.ClusterResource.NodeEvent |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private getClient(memberId MemberId) : CompletableFuture<LocalRaftClientProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method public enter(member GroupMember) : CompletableFuture<PrimaryTerm> in class io.atomix.primitive.partition.TestPrimaryElection |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package ClusterHeartbeat(memberId MemberId, type Member.Type, zone String, rack String, host String, tags Set<String>) in class io.atomix.cluster.impl.ClusterHeartbeat |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type addressProvider : Function<NodeId,Address> to addressProvider : Function<MemberId,Address> in method public RaftServerMessagingProtocol(messagingService MessagingService, serializer Serializer, addressProvider Function<MemberId,Address>) in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public DefaultRaftClient(clientId String, memberId MemberId, cluster Collection<MemberId>, protocol RaftClientProtocol, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.impl.DefaultRaftClient |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestRaftServerProtocol> to servers : Map<MemberId,TestRaftServerProtocol> in method public TestRaftServerProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public PrimaryBackupSession(sessionId SessionId, memberId MemberId, context PrimaryBackupServiceContext) in class io.atomix.protocols.backup.impl.PrimaryBackupSession |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method protected Member(id MemberId, type Type, address Address, zone String, rack String, host String, tags Set<String>) in class io.atomix.cluster.Member |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method private sendAndReceive(subject String, payload byte[], toMemberId MemberId, timeout Duration) : CompletableFuture<byte[]> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type counters : Map<NodeId,Integer> to counters : Map<MemberId,Integer> in method private updateCounters(counters Map<MemberId,Integer>) : void in class io.atomix.primitive.partition.impl.HashBasedPrimaryElectionService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method package server(memberId MemberId) : TestPrimaryBackupServerProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocol |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method private buildNode(nodeId int, type Member.Type) : Member in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method package ClusterHeartbeat(memberId MemberId, type Member.Type, zone String, rack String, host String, tags Set<String>) in class io.atomix.cluster.impl.ClusterHeartbeat |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public LocalRaftServerProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodes : Collection<NodeId> to nodes : Collection<MemberId> in method public TestClusterMembershipService(localNode MemberId, nodes Collection<MemberId>) in class io.atomix.cluster.TestClusterMembershipService |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public KeepAliveResponse(status Status, error RaftError, leader MemberId, members Collection<MemberId>, sessionIds long[]) in class io.atomix.protocols.raft.protocol.KeepAliveResponse |
From |
To |
|
Change Parameter Type nodes : Set<NodeId> to nodes : Set<MemberId> in method public multicast(subject String, message M, encoder Function<M,byte[]>, nodes Set<MemberId>) : void in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestPrimaryBackupServerProtocol> to servers : Map<MemberId,TestPrimaryBackupServerProtocol> in method public TestPrimaryBackupServerProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getEvent(listenerId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method private validateMembership(membershipService ClusterMembershipService) : boolean in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestPrimaryBackupServerProtocol> to servers : Map<MemberId,TestPrimaryBackupServerProtocol> in method public TestPrimaryBackupClientProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeInfo(nodeId String, clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public removeNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method protected sendAndReceive(memberId MemberId, type String, request T) : CompletableFuture<U> in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method protected buildClusterEventService(membershipService ClusterMembershipService, messagingService MessagingService) : ManagedClusterEventingService in class io.atomix.cluster.AtomixCluster |
From |
To |
|
Change Parameter Type member : NodeId to member : MemberId in method protected TransferRequest(member MemberId) in class io.atomix.protocols.raft.protocol.TransferRequest |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public reset(leader MemberId, servers Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Parameter Type vote : NodeId to vote : MemberId in method public storeVote(vote MemberId) : void in class io.atomix.protocols.raft.storage.system.MetaStore |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method protected sendAsync(memberId MemberId, type String, request Object) : CompletableFuture<Void> in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public isMember(member Member) : boolean in class io.atomix.primitive.partition.MemberGroup |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public withMembers(members Collection<MemberId>) : Builder in class io.atomix.protocols.raft.protocol.HeartbeatRequest.Builder |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method private doUnicast(subject String, payload byte[], toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method private changed(leader MemberId, members Collection<MemberId>) : boolean in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public withLeader(leader MemberId) : Builder in class io.atomix.protocols.raft.protocol.ConfigureRequest.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultPartitionManagementService(membershipService ClusterMembershipService, communicationService ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry, electionService PrimaryElectionService, sessionIdService SessionIdService) in class io.atomix.primitive.partition.impl.DefaultPartitionManagementService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestRaftClientProtocol> to clients : Map<MemberId,TestRaftClientProtocol> in method public TestRaftClientProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public join(members Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type primary : NodeId to primary : MemberId in method public request(primitive PrimitiveDescriptor, primary MemberId, term long, index long, operations List<BackupOperation>) : BackupRequest in class io.atomix.protocols.backup.protocol.BackupRequest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public persistent(memberId MemberId, address Address) : Member in class io.atomix.cluster.Member |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public addNode(member Member) : void in class io.atomix.cluster.ManagedPersistentMetadataService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method private nextNode(type Member.Type) : Member in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<TestPrimaryBackupServerProtocol> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method package server(memberId MemberId) : TestRaftServerProtocol in class io.atomix.protocols.raft.protocol.TestRaftProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public removeListener(listenerId String, clusterMembershipService ClusterMembershipService, events EventManager) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type members : NodeId... to members : MemberId... in method public withMembers(members MemberId...) : Builder in class io.atomix.protocols.raft.partition.RaftPartitionGroup.Builder |
From |
To |
|
Change Parameter Type candidate : NodeId to candidate : MemberId in method public setLastVotedFor(candidate MemberId) : void in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public newServerProtocol(memberId MemberId) : RaftServerProtocol in class io.atomix.protocols.raft.protocol.TestRaftProtocolFactory |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package client(memberId MemberId) : LocalRaftClientProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |
|
Change Parameter Type nodes : Collection<Node> to members : Collection<Member> in method public ClusterMetadata(members Collection<Member>) in class io.atomix.cluster.ClusterMetadata |
From |
To |
|
Change Parameter Type sender : BiFunction<NodeId,T,CompletableFuture<U>> to sender : BiFunction<MemberId,T,CompletableFuture<U>> in method protected sendRequest(request T, sender BiFunction<MemberId,T,CompletableFuture<U>>, future CompletableFuture<U>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method protected buildClusterMessagingService(membershipService ClusterMembershipService, messagingService MessagingService) : ManagedClusterMessagingService in class io.atomix.cluster.AtomixCluster |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public createSession(sessionId long, memberId MemberId) : PrimaryBackupSession in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Change Parameter Type nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public RaftProxyManager(clientId String, memberId MemberId, protocol RaftClientProtocol, selectorManager MemberSelectorManager, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.proxy.impl.RaftProxyManager |
From |
To |
|
Change Parameter Type node : NodeId to node : MemberId in method protected handleResponse(request T, sender BiFunction, count int, selectionId int, node MemberId, response RaftResponse, error Throwable, future CompletableFuture) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type sender : BiFunction<NodeId,T,CompletableFuture<U>> to sender : BiFunction<MemberId,T,CompletableFuture<U>> in method protected sendRequest(request T, sender BiFunction<MemberId,T,CompletableFuture<U>>, count int, future CompletableFuture<U>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public InstallRequest(term long, leader MemberId, index long, timestamp long, offset int, data byte[], complete boolean) in class io.atomix.protocols.raft.protocol.InstallRequest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public newClientProtocol(memberId MemberId) : RaftClientProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocolFactory |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public setId(id MemberId) : MemberConfig in class io.atomix.cluster.MemberConfig |
From |
To |
|
Change Parameter Type members : Set<NodeId> to members : Set<MemberId> in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type that : NodeId to that : MemberId in method public compareTo(that MemberId) : int in class io.atomix.cluster.MemberId |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type node : NodeId to node : MemberId in method public withNodeId(node MemberId) : Builder in class io.atomix.protocols.raft.protocol.OpenSessionRequest.Builder |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestRaftServerProtocol> to servers : Map<MemberId,TestRaftServerProtocol> in method public TestRaftClientProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type config : NodeConfig to config : MemberConfig in method public Member(config MemberConfig) in class io.atomix.cluster.Member |
From |
To |
|
Change Parameter Type localNode : NodeConfig to localNode : MemberConfig in method public setLocalNode(localNode MemberConfig) : ClusterConfig in class io.atomix.cluster.ClusterConfig |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package InternalSubscriptionInfo(memberId MemberId, topic String, logicalTimestamp LogicalTimestamp, tombstone boolean) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService.InternalSubscriptionInfo |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method package client(memberId MemberId) : TestRaftClientProtocol in class io.atomix.protocols.raft.protocol.TestRaftProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type event : LeadershipEvent<NodeId> to event : LeadershipEvent<MemberId> in method public onEvent(event LeadershipEvent<MemberId>) : void in class io.atomix.core.election.impl.LeaderElectionTest.LeaderEventListener |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public bootstrap(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type localNode : Node to localMember : Member in method public withLocalNode(localMember Member) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method package Enter(partitionId PartitionId, member GroupMember) in class io.atomix.primitive.partition.impl.PrimaryElectorOperations.Enter |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultClusterEventingService(membershipService ClusterMembershipService, messagingService MessagingService) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupServiceContext(serverName String, primitiveId PrimitiveId, primitiveType PrimitiveType<?,?,?>, descriptor PrimitiveDescriptor, threadContext ThreadContext, clusterMembershipService ClusterMembershipService, memberGroupService MemberGroupService, protocol PrimaryBackupServerProtocol, primaryElection PrimaryElection) in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public RaftClusterContext(localMemberId MemberId, raft RaftContext) in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public newServerProtocol(memberId MemberId) : RaftServerProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocolFactory |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public PartitionMetadata(id PartitionId, members Collection<MemberId>) in class io.atomix.primitive.partition.PartitionMetadata |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method protected updateTermAndLeader(term long, leader MemberId) : boolean in class io.atomix.protocols.raft.roles.AbstractRole |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public HeartbeatRequest(leader MemberId, members Collection<MemberId>) in class io.atomix.protocols.raft.protocol.HeartbeatRequest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package InternalSubscriptionInfo(memberId MemberId, topic String, logicalTimestamp LogicalTimestamp) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService.InternalSubscriptionInfo |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package server(memberId MemberId) : LocalRaftServerProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |
|
Change Parameter Type localNode : Node to localMember : Member in method public withLocalNode(localMember Member) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public addNodeListener(nodeId String, clusterMembershipService ClusterMembershipService, events EventManager) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type left : Collection<NodeId> to left : Collection<MemberId> in method private matches(left Collection<MemberId>, right Collection<MemberId>) : boolean in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private onLeaderChange(memberId MemberId) : void in class io.atomix.protocols.raft.proxy.impl.DefaultRaftProxy |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestPrimaryBackupServerProtocol> to servers : Map<MemberId,TestPrimaryBackupServerProtocol> in method public TestPrimaryBackupProtocol(servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public withLeader(leader MemberId) : Builder in class io.atomix.protocols.raft.protocol.AppendRequest.Builder |
From |
To |
|
Change Parameter Type cluster : ClusterService to membershipService : ClusterMembershipService in method public DefaultClusterMessagingService(membershipService ClusterMembershipService, messagingService MessagingService) in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public CorePrimitivesService(executorService ScheduledExecutorService, membershipService ClusterMembershipService, communicationService ClusterMessagingService, eventService ClusterEventingService, partitionService PartitionService, config AtomixConfig) in class io.atomix.core.impl.CorePrimitivesService |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public listen(cluster Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.impl.DefaultRaftServer |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public HashBasedPrimaryElection(partitionId PartitionId, clusterMembershipService ClusterMembershipService, electionService HashBasedPrimaryElectionService) in class io.atomix.primitive.partition.impl.HashBasedPrimaryElection |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.backup.PrimaryBackupClient.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type instance : Node to instance : Member in method public ClusterEvent(type Type, instance Member, time long) in class io.atomix.cluster.ClusterEvent |
From |
To |
|
Change Parameter Type node : Node to member : Member in method private deactivateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type localNode : Node to localMember : Member in method public DefaultClusterMembershipService(localMember Member, bootstrapMetadataService BootstrapMetadataService, persistentMetadataService PersistentMetadataService, messagingService MessagingService, broadcastService BroadcastService) in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.raft.RaftServer.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected startAtomix(type Member.Type, id int, persistentIds List<Integer>, ephemeralIds List<Integer>) : CompletableFuture<Atomix> in class io.atomix.core.AtomixTest |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method package client(memberId MemberId) : TestPrimaryBackupClientProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocol |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, encoder Function<M,byte[]>, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupClient(clientName String, clusterMembershipService ClusterMembershipService, protocol PrimaryBackupClientProtocol, primaryElection PrimaryElection, sessionIdService SessionIdService, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.backup.PrimaryBackupClient |
From |
To |
|
Change Parameter Type right : Collection<NodeId> to right : Collection<MemberId> in method private matches(left Collection<MemberId>, right Collection<MemberId>) : boolean in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public LocalRaftClientProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public newServerProtocol(memberId MemberId) : PrimaryBackupServerProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocolFactory |
From |
To |
|
Change Parameter Type keyFunction : Function<Node,String> to keyFunction : Function<Member,String> in method protected groupNodes(members Collection<Member>, keyFunction Function<Member,String>) : Collection<MemberGroup> in class io.atomix.primitive.partition.MemberGroupStrategy |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftTest.TestMember |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package BackupQueue(memberId MemberId) in class io.atomix.protocols.backup.roles.SynchronousReplicator.BackupQueue |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public DefaultRaftClient(clientId String, memberId MemberId, cluster Collection<MemberId>, protocol RaftClientProtocol, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.impl.DefaultRaftClient |
From |
To |
|
Change Parameter Type node : Node to member : Member in method private createServer(member Member, members List<Member>) : RaftServer in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public addNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public reset(leader MemberId, members Collection<MemberId>) : MemberSelector in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public join(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type node : NodeId to node : MemberId in method public request(primitive PrimitiveDescriptor, session long, node MemberId, operation PrimitiveOperation) : ExecuteRequest in class io.atomix.protocols.backup.protocol.ExecuteRequest |
From |
To |
|
Change Parameter Type servers : Map<NodeId,LocalRaftServerProtocol> to servers : Map<MemberId,LocalRaftServerProtocol> in method public LocalRaftProtocol(serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftPerformanceTest.TestMember |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method public enter(member GroupMember) : CompletableFuture<PrimaryTerm> in class io.atomix.primitive.partition.impl.HashBasedPrimaryElection |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public removeNode(member Member) : void in class io.atomix.cluster.ManagedPersistentMetadataService |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public withLeader(leader MemberId) : Builder in class io.atomix.protocols.raft.protocol.HeartbeatRequest.Builder |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method protected Builder(id MemberId) in class io.atomix.cluster.Member.Builder |
From |
To |
|
Change Parameter Type members : Set<NodeId> to members : Set<MemberId> in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type instance : Node to instance : Member in method public ClusterEvent(type Type, instance Member) in class io.atomix.cluster.ClusterEvent |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private handleBootstrap(memberId MemberId) : PartitionGroupInfo in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Change Parameter Type primary : NodeId to primary : MemberId in method public BackupRequest(primitive PrimitiveDescriptor, primary MemberId, term long, index long, operations List<BackupOperation>) in class io.atomix.protocols.backup.protocol.BackupRequest |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, encoder Function<M,byte[]>, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type node : Node to member : Member in method private updateNode(member Member) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected createAtomix(type Member.Type, id int, persistentIds List<Integer>, ephemeralIds List<Integer>, profiles Profile...) : Atomix in class io.atomix.core.AbstractAtomixTest |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected startAtomix(type Member.Type, id int, persistentNodes List<Integer>, ephemeralNodes List<Integer>, profiles Profile...) : CompletableFuture<Atomix> in class io.atomix.core.AtomixTest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public bootstrap(cluster MemberId...) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type addressProvider : Function<NodeId,Address> to addressProvider : Function<MemberId,Address> in method public RaftClientMessagingProtocol(messagingService MessagingService, serializer Serializer, addressProvider Function<MemberId,Address>) in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public MemberSelector(leader MemberId, members Collection<MemberId>, strategy CommunicationStrategy, selectors MemberSelectorManager) in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public join(cluster Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.impl.DefaultRaftServer |
From |
To |
|
Change Parameter Type candidate : NodeId to candidate : MemberId in method public withCandidate(candidate MemberId) : Builder in class io.atomix.protocols.raft.protocol.VoteRequest.Builder |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type node : Node to member : Member in method package NodeInfo(member Member) in class io.atomix.rest.resources.ClusterResource.NodeInfo |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupProxy(clientName String, sessionId SessionId, primitiveType PrimitiveType, descriptor PrimitiveDescriptor, clusterMembershipService ClusterMembershipService, protocol PrimaryBackupClientProtocol, primaryElection PrimaryElection, threadContext ThreadContext) in class io.atomix.protocols.backup.proxy.PrimaryBackupProxy |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public newBuilder(cluster MemberId...) : Builder in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type listener : Consumer<NodeId> to listener : Consumer<MemberId> in method public addLeaderChangeListener(listener Consumer<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.MemberSelectorManager |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getEvent(clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type servers : Map<NodeId,LocalRaftServerProtocol> to servers : Map<MemberId,LocalRaftServerProtocol> in method public LocalRaftServerProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type servers : Map<NodeId,TestRaftServerProtocol> to servers : Map<MemberId,TestRaftServerProtocol> in method public TestRaftProtocol(servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeEvent(nodeId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method public enter(member GroupMember) : CompletableFuture<PrimaryTerm> in class io.atomix.primitive.partition.PrimaryElection |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public reset(leader MemberId, members Collection<MemberId>) : MemberSelector in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type candidates : List<Member> to candidates : List<GroupMember> in method public PrimaryTerm(term long, primary GroupMember, candidates List<GroupMember>) in class io.atomix.primitive.partition.PrimaryTerm |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public listen(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type members : Set<NodeId> to members : Set<MemberId> in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method private buildPartitionService(config AtomixConfig, clusterMembershipService ClusterMembershipService, messagingService ClusterMessagingService, primitiveTypeRegistry PrimitiveTypeRegistry) : ManagedPartitionService in class io.atomix.core.Atomix |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public getMemberState(id MemberId) : RaftMemberContext in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type clients : Map<NodeId,LocalRaftClientProtocol> to clients : Map<MemberId,LocalRaftClientProtocol> in method public LocalRaftServerProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public bootstrap(cluster Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method package BackupQueue(memberId MemberId) in class io.atomix.protocols.backup.roles.AsynchronousReplicator.BackupQueue |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public CorePrimitiveManagementService(executorService ScheduledExecutorService, membershipService ClusterMembershipService, communicationService ClusterMessagingService, eventService ClusterEventingService, partitionService PartitionService, primitiveRegistry PrimitiveRegistry) in class io.atomix.core.impl.CorePrimitiveManagementService |
From |
To |
|
Change Parameter Type member : NodeId to member : MemberId in method public withMember(member MemberId) : Builder in class io.atomix.protocols.raft.protocol.TransferRequest.Builder |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public withLeader(leader MemberId) : Builder in class io.atomix.protocols.raft.protocol.KeepAliveResponse.Builder |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public Builder(localMemberId MemberId) in class io.atomix.protocols.raft.impl.DefaultRaftServer.Builder |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method private buildNode(nodeId int, type Member.Type) : Member in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Parameter Type clients : Map<NodeId,LocalRaftClientProtocol> to clients : Map<MemberId,LocalRaftClientProtocol> in method public LocalRaftProtocol(serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeEvent(nodeId String, listenerId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method private changed(leader MemberId, members Collection<MemberId>) : boolean in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type bootstrapNodes : Node... to bootstrapMembers : Member... in method public withNodes(bootstrapMembers Member...) : Builder in class io.atomix.cluster.ClusterMetadata.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type node : Node to member : Member in method private bootstrap(member Member) : CompletableFuture<Void> in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Change Parameter Type node : Node to member : Member in method private activateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Parameter Type node : NodeId to node : MemberId in method public ExecuteRequest(primitive PrimitiveDescriptor, session long, node MemberId, operation PrimitiveOperation) in class io.atomix.protocols.backup.protocol.ExecuteRequest |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method private buildNode(nodeId int, type Member.Type) : Member in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public getRemoteMember(id MemberId) : DefaultRaftMember in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type servers : Collection<NodeId> to servers : Collection<MemberId> in method public reset(leader MemberId, servers Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type nodes : Collection<NodeConfig> to nodes : Collection<MemberConfig> in method public setNodes(nodes Collection<MemberConfig>) : ClusterConfig in class io.atomix.cluster.ClusterConfig |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public getMemberGroup(member Member) : MemberGroup in class io.atomix.primitive.partition.MemberGroupService |
From |
To |
|
Change Parameter Type function : BiFunction<NodeId,T,CompletableFuture<U>> to function : BiFunction<MemberId,T,CompletableFuture<U>> in method protected forward(request T, function BiFunction<MemberId,T,CompletableFuture<U>>) : CompletableFuture<U> in class io.atomix.protocols.raft.roles.AbstractRole |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method public enter(member GroupMember) : CompletableFuture<PrimaryTerm> in class io.atomix.primitive.partition.impl.DefaultPrimaryElection |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<LocalRaftServerProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public getOrCreateSession(sessionId long, memberId MemberId) : PrimaryBackupSession in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public withId(id MemberId) : Builder in class io.atomix.cluster.Member.Builder |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public newClientProtocol(memberId MemberId) : RaftClientProtocol in class io.atomix.protocols.raft.protocol.TestRaftProtocolFactory |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public KeepAliveResponse(status Status, error RaftError, leader MemberId, members Collection<MemberId>, sessionIds long[]) in class io.atomix.protocols.raft.protocol.KeepAliveResponse |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.backup.PrimaryBackupServer.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public newClientProtocol(memberId MemberId) : PrimaryBackupClientProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocolFactory |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public ephemeral(memberId MemberId, address Address) : Member in class io.atomix.cluster.Member |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected startAtomix(type Member.Type, id int, persistentIds List<Integer>, ephemeralIds List<Integer>, builderFunction Function<Atomix.Builder,Atomix>) : CompletableFuture<Atomix> in class io.atomix.core.AtomixTest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getClient(memberId MemberId) : CompletableFuture<TestRaftClientProtocol> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public TestRaftServerProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type members : NodeId... to members : MemberId... in method public connect(members MemberId...) : CompletableFuture<RaftClient> in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected startAtomix(type Member.Type, id int, persistentNodes List<Integer>, profiles Profile...) : CompletableFuture<Atomix> in class io.atomix.core.AtomixTest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.ClusterMembershipService |
From |
To |
|
Change Parameter Type members : Node... to members : Member... in method public withMembers(members Member...) : Builder in class io.atomix.protocols.raft.partition.RaftPartitionGroup.Builder |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public ReplicatedMember(id MemberId, type Type, address Address, zone String, rack String, host String, tags Set<String>, timestamp LogicalTimestamp, tombstone boolean) in class io.atomix.cluster.impl.ReplicatedMember |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNode(clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<TestRaftServerProtocol> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public getMember(id MemberId) : DefaultRaftMember in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type coreNodes : Node... to coreMembers : Member... in method public withNodes(coreMembers Member...) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Change Parameter Type members : NodeId... to members : MemberId... in method public bootstrap(members MemberId...) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type servers : Collection<NodeId> to servers : Collection<MemberId> in method public resetConnections(leader MemberId, servers Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyManager |
From |
To |
|
Change Parameter Type member : NodeId to member : MemberId in method public RaftSession(sessionId SessionId, member MemberId, name String, primitiveType PrimitiveType, readConsistency ReadConsistency, minTimeout long, maxTimeout long, lastUpdated long, context RaftServiceContext, server RaftContext, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.session.RaftSession |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public HashBasedPrimaryElectionService(clusterMembershipService ClusterMembershipService, messagingService ClusterMessagingService) in class io.atomix.primitive.partition.impl.HashBasedPrimaryElectionService |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public listen(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public listen(cluster MemberId...) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public bootstrap(cluster Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.impl.DefaultRaftServer |
From |
To |
|
Change Parameter Type nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.cluster.ClusterMetadata.Builder |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getClient(memberId MemberId) : CompletableFuture<TestPrimaryBackupClientProtocol> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method private buildPartitions(membershipService ClusterMembershipService) : Collection<PartitionMetadata> in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public RaftContext(name String, localMemberId MemberId, membershipService ClusterMembershipService, protocol RaftServerProtocol, storage RaftStorage, primitiveTypes PrimitiveTypeRegistry, threadModel ThreadModel, threadPoolSize int) in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public RaftPartitionServer(partition RaftPartition, localMemberId MemberId, membershipService ClusterMembershipService, clusterCommunicator ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry) in class io.atomix.protocols.raft.partition.impl.RaftPartitionServer |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public RaftPartitionClient(partition RaftPartition, localMemberId MemberId, protocol RaftClientProtocol) in class io.atomix.protocols.raft.partition.impl.RaftPartitionClient |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method public Registration(member GroupMember, sessionId long) in class io.atomix.primitive.partition.impl.PrimaryElectorService.Registration |
From |
To |
|
Change Parameter Type coreNodes : Node... to coreMembers : Member... in method public withNodes(coreMembers Member...) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public HeartbeatRequest(leader MemberId, members Collection<MemberId>) in class io.atomix.protocols.raft.protocol.HeartbeatRequest |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public GroupMember(memberId MemberId, groupId MemberGroupId) in class io.atomix.primitive.partition.GroupMember |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type members : List<Node> to members : List<Member> in method private createServer(member Member, members List<Member>) : RaftServer in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultPartitionService(membershipService ClusterMembershipService, messagingService ClusterMessagingService, primitiveTypeRegistry PrimitiveTypeRegistry, systemGroup ManagedPartitionGroup, groups Collection<ManagedPartitionGroup>) in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public DefaultRaftMember(id MemberId, type Type, updated Instant) in class io.atomix.protocols.raft.cluster.impl.DefaultRaftMember |
From |
To |
|
Change Parameter Type primary : NodeId to primary : MemberId in method public resetTerm(term long, primary MemberId) : void in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Change Parameter Type member : Member to member : GroupMember in method package transfer(member GroupMember) : ElectionState in class io.atomix.primitive.partition.impl.PrimaryElectorService.ElectionState |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodes(clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public MemberSelector(leader MemberId, members Collection<MemberId>, strategy CommunicationStrategy, selectors MemberSelectorManager) in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public RaftPartitionServer(partition RaftPartition, localMemberId MemberId, membershipService ClusterMembershipService, clusterCommunicator ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry) in class io.atomix.protocols.raft.partition.impl.RaftPartitionServer |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public builder(cluster Collection<MemberId>) : Builder in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type node : Node to member : Member in method public isMember(member Member) : boolean in class io.atomix.primitive.partition.impl.NodeMemberGroup |
From |
To |
|
Change Parameter Type servers : Map<NodeId,LocalRaftServerProtocol> to servers : Map<MemberId,LocalRaftServerProtocol> in method public LocalRaftClientProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public join(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public Builder(cluster Collection<MemberId>) in class io.atomix.protocols.raft.impl.DefaultRaftClient.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeIds : Set<NodeId> to memberIds : Set<MemberId> in method public multicast(subject String, message M, memberIds Set<MemberId>) : void in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public resetConnections(leader MemberId, servers Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyManager |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupServerContext(serverName String, clusterMembershipService ClusterMembershipService, memberGroupService ManagedMemberGroupService, protocol PrimaryBackupServerProtocol, threadContextFactory ThreadContextFactory, primitiveTypes PrimitiveTypeRegistry, primaryElection PrimaryElection) in class io.atomix.protocols.backup.impl.PrimaryBackupServerContext |
From |
To |
|
Change Parameter Type id : NodeId to id : MemberId in method public StatefulMember(id MemberId, type Type, address Address, zone String, rack String, host String, tags Set<String>) in class io.atomix.cluster.impl.StatefulMember |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type listener : Consumer<NodeId> to listener : Consumer<MemberId> in method public removeLeaderChangeListener(listener Consumer<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.MemberSelectorManager |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public listen(cluster MemberId...) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.RaftCluster |
From |
To |
|
Change Parameter Type clients : Map<NodeId,LocalRaftClientProtocol> to clients : Map<MemberId,LocalRaftClientProtocol> in method public LocalRaftClientProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type members : NodeId... to members : MemberId... in method public join(members MemberId...) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type members : Set<NodeId> to members : Set<MemberId> in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public newBuilder(cluster Collection<MemberId>) : Builder in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestPrimaryBackupClientProtocol> to clients : Map<MemberId,TestPrimaryBackupClientProtocol> in method public TestPrimaryBackupProtocol(servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public TestRaftClientProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftClientProtocol |
From |
To |
|
Change Parameter Type change : LeadershipEvent<NodeId> to change : LeadershipEvent<MemberId> in method public onEvent(change LeadershipEvent<MemberId>) : void in class io.atomix.core.election.impl.LeaderElectorTest.LeaderEventListener |
From |
To |
|
Change Parameter Type members : Set<NodeId> to members : Set<MemberId> in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Change Parameter Type clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultMemberGroupService(membershipService ClusterMembershipService, memberGroupProvider MemberGroupProvider) in class io.atomix.primitive.partition.impl.DefaultMemberGroupService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public withNodeId(memberId MemberId) : Builder in class io.atomix.protocols.raft.RaftClient.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<LocalRaftServerProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type leader : NodeId to leader : MemberId in method public withLeader(leader MemberId) : Builder in class io.atomix.protocols.raft.protocol.InstallRequest.Builder |
From |
To |
|
Change Parameter Type clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public removeNodeListener(nodeId String, listenerId String, clusterMembershipService ClusterMembershipService, events EventManager) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Parameter Type digests : Map<NodeId,NodeDigest> to digests : Map<MemberId,NodeDigest> in method package ClusterMetadataAdvertisement(digests Map<MemberId,NodeDigest>) in class io.atomix.cluster.impl.ClusterMetadataAdvertisement |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method protected Builder(localMemberId MemberId) in class io.atomix.protocols.raft.RaftServer.Builder |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, toMemberId MemberId) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method protected buildAtomix(type Member.Type, id int, persistentNodes List<Integer>, ephemeralNodes List<Integer>) : Atomix.Builder in class io.atomix.core.AbstractAtomixTest |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public bootstrap(cluster Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Change Parameter Type cluster : NodeId... to cluster : MemberId... in method public builder(cluster MemberId...) : Builder in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public resetAll(leader MemberId, members Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.MemberSelectorManager |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type nodeIds : Set<NodeId> to memberIds : Set<MemberId> in method public multicast(subject String, message M, encoder Function<M,byte[]>, memberIds Set<MemberId>) : void in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<TestPrimaryBackupServerProtocol> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type primary : Member to primary : GroupMember in method public PrimaryTerm(term long, primary GroupMember, candidates List<GroupMember>) in class io.atomix.primitive.partition.PrimaryTerm |
From |
To |
|
Change Parameter Type candidate : NodeId to candidate : MemberId in method public withCandidate(candidate MemberId) : Builder in class io.atomix.protocols.raft.protocol.PollRequest.Builder |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Change Parameter Type nodes : Set<Node> to members : Set<Member> in method public NodeMemberGroup(groupId MemberGroupId, members Set<Member>) in class io.atomix.primitive.partition.impl.NodeMemberGroup |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method private createServer(memberId MemberId) : PrimaryBackupServer in class io.atomix.protocols.backup.PrimaryBackupTest |
From |
To |
|
Change Parameter Type addressProvider : Function<NodeId,Address> to addressProvider : Function<MemberId,Address> in method public RaftMessagingProtocol(messagingService MessagingService, serializer Serializer, addressProvider Function<MemberId,Address>) in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Change Parameter Type localNode : NodeId to localNode : MemberId in method public TestClusterMembershipService(localNode MemberId, nodes Collection<MemberId>) in class io.atomix.cluster.TestClusterMembershipService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<TestRaftServerProtocol> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method protected address(memberId MemberId) : Address in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Change Parameter Type otherMembers : Collection<NodeId> to otherMembers : Collection<MemberId> in method public join(otherMembers Collection<MemberId>) : CompletableFuture<Void> in class io.atomix.protocols.raft.partition.impl.RaftPartitionServer |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Change Parameter Type type : Node.Type to type : Member.Type in method public setType(type Member.Type) : MemberConfig in class io.atomix.cluster.MemberConfig |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestRaftClientProtocol> to clients : Map<MemberId,TestRaftClientProtocol> in method public TestRaftServerProtocol(memberId MemberId, servers Map<MemberId,TestRaftServerProtocol>, clients Map<MemberId,TestRaftClientProtocol>, context ThreadContext) in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public TestPrimaryBackupServerProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.TestRaftServerProtocol |
From |
To |
|
Change Parameter Type memberId : NodeId to memberId : MemberId in method public TestPrimaryBackupClientProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Change Parameter Type members : Collection<NodeId> to members : Collection<MemberId> in method public connect(members Collection<MemberId>) : CompletableFuture<RaftClient> in class io.atomix.protocols.raft.RaftClient |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.TestClusterMembershipService |
From |
To |
|
Change Parameter Type nodeId : NodeId to memberId : MemberId in method public digest(memberId MemberId) : NodeDigest in class io.atomix.cluster.impl.ClusterMetadataAdvertisement |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public connect(cluster Collection<MemberId>) : CompletableFuture<RaftClient> in class io.atomix.protocols.raft.impl.DefaultRaftClient |
From |
To |
|
Change Parameter Type clients : Map<NodeId,TestPrimaryBackupClientProtocol> to clients : Map<MemberId,TestPrimaryBackupClientProtocol> in method public TestPrimaryBackupServerProtocol(memberId MemberId, servers Map<MemberId,TestPrimaryBackupServerProtocol>, clients Map<MemberId,TestPrimaryBackupClientProtocol>) in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Change Parameter Type localNodeId : NodeId to localMemberId : MemberId in method public builder(localMemberId MemberId) : Builder in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Parameter Type cluster : Collection<NodeId> to cluster : Collection<MemberId> in method public listen(cluster Collection<MemberId>) : CompletableFuture<RaftServer> in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Change Variable Type localNode3 : Node to localMember3 : Member in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type nodes : List<Node> to members : List<Member> in method private gossip() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type futures : CompletableFuture<ClusterService>[] to futures : CompletableFuture<ClusterMembershipService>[] in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testNonLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type clusterService2 : ManagedClusterService to clusterService2 : ManagedClusterMembershipService in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type elector3 : AsyncLeaderElector<NodeId> to elector3 : AsyncLeaderElector<MemberId> in method public testLeaderBalance() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type node : Node to node : Member in method private validateMembership(membershipService ClusterMembershipService) : boolean in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testNonLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type staleNodes : Set<NodeId> to staleNodes : Set<MemberId> in method private handleAdvertisement(address Address, payload byte[]) : byte[] in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type replicatedNode : ReplicatedNode to replicatedNode : ReplicatedMember in method public removeNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testQueries() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type localNode5 : Node to localMember5 : Member in method public testClusterMetadataService() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type clusterService3 : ClusterService to clusterMembershipService3 : ClusterMembershipService in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method private createClient() : RaftClient in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Change Variable Type localNode2 : Node to localMember2 : Member in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type localNode2 : Node to localMember2 : Member in method public testSingleNodeBootstrap() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type elector3 : AsyncLeaderElector<NodeId> to elector3 : AsyncLeaderElector<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type bootstrapNodes : List<NodeConfig> to bootstrapNodes : List<MemberConfig> in method public main(args String[]) : void in class io.atomix.agent.AtomixAgent |
From |
To |
|
Change Variable Type node : Node to member : Member in method public broadcast(topic String, message M, encoder Function<M,byte[]>) : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type dataNodes : Set<NodeId> to dataNodes : Set<MemberId> in method private handleMetadataEvent(event ClusterMetadataEvent) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type oldLeader : NodeId to oldLeader : MemberId in method public resetAll(leader MemberId, members Collection<MemberId>) : void in class io.atomix.protocols.raft.proxy.impl.MemberSelectorManager |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method private handleMetadataEvent(event ClusterMetadataEvent) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testRun() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type node : ReplicatedNode to node : ReplicatedMember in method private handleUpdate(address Address, payload byte[]) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type localNode1 : Node to localMember1 : Member in method public testSingleNodeBootstrap() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type nodes : Collection<Node> to members : Collection<Member> in method protected buildAtomix(type Member.Type, id int, persistentNodes List<Integer>, ephemeralNodes List<Integer>) : Atomix.Builder in class io.atomix.core.AbstractAtomixTest |
From |
To |
|
Change Variable Type nodes : Collection<Node> to members : Collection<Member> in method protected buildAtomix(nodeId int) : Atomix in class io.atomix.rest.impl.VertxRestServiceTest |
From |
To |
|
Change Variable Type localNode1 : Node to localMember1 : Member in method public testClusterMetadataService() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type node : Node to member : Member in method private gossip() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method private sendAdvertisement(address Address) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type member : Member to member : GroupMember in method public equals(object Object) : boolean in class io.atomix.primitive.partition.GroupMember |
From |
To |
|
Change Variable Type node : Node to member : Member in method private recomputeTerm() : void in class io.atomix.primitive.partition.impl.HashBasedPrimaryElection |
From |
To |
|
Change Variable Type entry : Map.Entry<NodeId,Integer> to entry : Map.Entry<MemberId,Integer> in method private updateCounters(counters Map<MemberId,Integer>) : void in class io.atomix.primitive.partition.impl.HashBasedPrimaryElectionService |
From |
To |
|
Change Variable Type localNode1 : Node to localMember1 : Member in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type localNode : NodeConfig to localNode : MemberConfig in method public main(args String[]) : void in class io.atomix.agent.AtomixAgent |
From |
To |
|
Change Variable Type replicatedNode : ReplicatedNode to replicatedNode : ReplicatedMember in method public addNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type set : Set<NodeId> to set : Set<MemberId> in method private buildPartitions(membershipService ClusterMembershipService) : Collection<PartitionMetadata> in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testNonLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method protected groupNodes(members Collection<Member>, keyFunction Function<Member,String>) : Collection<MemberGroup> in class io.atomix.primitive.partition.MemberGroupStrategy |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method public unicast(topic String, message M, encoder Function<M,byte[]>) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type leader : NodeId to leader : MemberId in method public getLeader() : DefaultRaftMember in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Change Variable Type primary : Member to primary : GroupMember in method public getPrimitives(primitiveType PrimitiveType) : CompletableFuture<Set<String>> in class io.atomix.protocols.backup.PrimaryBackupClient |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method public reset(members Set<MemberId>, request ResetRequest) : void in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Change Variable Type candidates : List<Member> to candidates : List<GroupMember> in method public testPrimaryTerm() : void in class io.atomix.primitive.partition.PrimaryTermTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method private sendAndReceive(subject String, payload byte[], toMemberId MemberId, timeout Duration) : CompletableFuture<byte[]> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Variable Type node : Node to member : Member in method private nextNode(type Member.Type) : Member in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type clusterNodes : Stream<StatefulNode> to clusterNodes : Stream<StatefulMember> in method private sendHeartbeats() : CompletableFuture<Void> in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type bootstrap : List<Node> to bootstrap : List<Member> in method private buildClusterMetadata(bootstrapNodes Integer...) : ClusterMetadata in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type node : NodeId to node : MemberId in method public installSnapshot(reader SnapshotReader) : void in class io.atomix.protocols.raft.service.RaftServiceContext |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type election3 : AsyncLeaderElection<NodeId> to election3 : AsyncLeaderElection<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testLeaderBalance() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type clusterService3 : ManagedClusterService to clusterService3 : ManagedClusterMembershipService in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type localNode2 : Node to localMember2 : Member in method public testClusterMetadataService() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type localNodeType : Node.Type to localNodeType : Member.Type in method public main(args String[]) : void in class io.atomix.agent.AtomixAgent |
From |
To |
|
Change Variable Type backups : List<Member> to backups : List<GroupMember> in method public backups(numBackups int) : List<GroupMember> in class io.atomix.primitive.partition.PrimaryTerm |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testQueries() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type clusterService1 : ClusterService to clusterMembershipService1 : ClusterMembershipService in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type nodes : List<Node> to members : List<Member> in method public main(args String[]) : void in class io.atomix.agent.AtomixAgent |
From |
To |
|
Change Variable Type election3 : AsyncLeaderElection<NodeId> to election3 : AsyncLeaderElection<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type missingNodes : Set<NodeId> to missingNodes : Set<MemberId> in method private handleMetadataEvent(event ClusterMetadataEvent) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testRun() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type bootstrap : List<Node> to bootstrap : List<Member> in method private buildClusterMetadata(bootstrapNodes Integer...) : ClusterMetadata in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type election1 : AsyncLeaderElection<NodeId> to election1 : AsyncLeaderElection<MemberId> in method public testLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type ephemeralClusterService : ManagedClusterService to ephemeralClusterService : ManagedClusterMembershipService in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type localNode : Node to localMember : Member in method protected buildClusterMembershipService(config ClusterConfig, bootstrapMetadataService BootstrapMetadataService, persistentMetadataService PersistentMetadataService, messagingService MessagingService, broadcastService BroadcastService) : ManagedClusterMembershipService in class io.atomix.cluster.AtomixCluster |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testNonLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type localNode3 : Node to localMember3 : Member in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type bootstrapNodes : Set<NodeId> to bootstrapNodes : Set<MemberId> in method private handleMetadataEvent(event ClusterMetadataEvent) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type coreNodes : List<NodeConfig> to coreNodes : List<MemberConfig> in method public main(args String[]) : void in class io.atomix.agent.AtomixAgent |
From |
To |
|
Change Variable Type localNode : Node to localMember : Member in method protected buildAtomix(type Member.Type, id int, persistentNodes List<Integer>, ephemeralNodes List<Integer>) : Atomix.Builder in class io.atomix.core.AbstractAtomixTest |
From |
To |
|
Change Variable Type localNode2 : Node to localMember2 : Member in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type candidates : List<Member> to candidates : List<GroupMember> in method private recomputeTerm() : void in class io.atomix.primitive.partition.impl.HashBasedPrimaryElection |
From |
To |
|
Change Variable Type localNode1 : Node to localMember1 : Member in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method private createClient() : PrimaryBackupClient in class io.atomix.protocols.backup.PrimaryBackupTest |
From |
To |
|
Change Variable Type clusterService1 : ManagedClusterService to clusterService1 : ManagedClusterMembershipService in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type node : ReplicatedNode to node : ReplicatedMember in method private sendAdvertisement(address Address) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type localNode3 : Node to localMember3 : Member in method public testClusterMetadataService() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type node : NodeId to node : MemberId in method protected sendRequest(request T, sender BiFunction<MemberId,T,CompletableFuture<U>>, count int, future CompletableFuture<U>) : void in class io.atomix.protocols.raft.proxy.impl.RaftProxyConnection |
From |
To |
|
Change Variable Type leadership1 : Leadership<NodeId> to leadership1 : Leadership<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testRun() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type localNodeType : Node.Type to localNodeType : Member.Type in method public start() : CompletableFuture<PrimaryBackupPartitionServer> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupPartitionServer |
From |
To |
|
Change Variable Type existingNode : StatefulNode to existingNode : StatefulMember in method private deactivateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type elector1 : AsyncLeaderElector<NodeId> to elector1 : AsyncLeaderElector<MemberId> in method public testQueries() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type leader : NodeId to leader : MemberId in method public backups() : Collection<MemberId> in class io.atomix.protocols.raft.partition.RaftPartition |
From |
To |
|
Change Variable Type leadership2 : Leadership<NodeId> to leadership2 : Leadership<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type existingNode : StatefulNode to existingNode : StatefulMember in method private handleMetadataEvent(event ClusterMetadataEvent) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type elector3 : AsyncLeaderElector<NodeId> to elector3 : AsyncLeaderElector<MemberId> in method public testAnoint() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testLeaderSessionClose() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testLeaderBalance() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type address : NodeId to address : MemberId in method private matches(left Collection<MemberId>, right Collection<MemberId>) : boolean in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Variable Type bootstrapNodes : Stream<StatefulNode> to bootstrapNodes : Stream<StatefulMember> in method private sendHeartbeats() : CompletableFuture<Void> in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testQueries() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type primary : Member to primary : GroupMember in method public testPrimaryTerm() : void in class io.atomix.primitive.partition.PrimaryTermTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method public getNodeInfo(nodeId String, clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Change Variable Type node : StatefulNode to node : StatefulMember in method private handleBroadcastMessage(message byte[]) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testPromote() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type election2 : AsyncLeaderElection<NodeId> to election2 : AsyncLeaderElection<MemberId> in method public testWithdraw() : void in class io.atomix.core.election.impl.LeaderElectionTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method public unicast(topic String, message M, encoder Function<M,byte[]>) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type selection : NodeId to selection : MemberId in method public next() : MemberId in class io.atomix.protocols.raft.proxy.impl.MemberSelector |
From |
To |
|
Change Variable Type existingNode : StatefulNode to existingNode : StatefulMember in method private activateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type clusterService2 : ClusterService to clusterMembershipService2 : ClusterMembershipService in method public testClusterEventService() : void in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type backup : NodeId to backup : MemberId in method public replicate(operation BackupOperation) : CompletableFuture<Void> in class io.atomix.protocols.backup.roles.AsynchronousReplicator |
From |
To |
|
Change Variable Type leader : NodeId to leader : MemberId in method public isLeader() : boolean in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Change Variable Type node : Node to member : Member in method public send(topic String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type backup : NodeId to backup : MemberId in method public replicate(operation BackupOperation) : CompletableFuture<Void> in class io.atomix.protocols.backup.roles.SynchronousReplicator |
From |
To |
|
Change Variable Type localNode4 : Node to localMember4 : Member in method public testClusterMetadataService() : void in class io.atomix.cluster.impl.DefaultPersistentMetadataServiceTest |
From |
To |
|
Change Variable Type statefulNode : StatefulNode to statefulNode : StatefulMember in method private activateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Change Variable Type member : Member to member : GroupMember in method public backups(numBackups int) : List<GroupMember> in class io.atomix.primitive.partition.PrimaryTerm |
From |
To |
|
Change Variable Type nodeId : NodeId to memberId : MemberId in method public send(topic String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Change Variable Type groups : Map<String,Set<Node>> to groups : Map<String,Set<Member>> in method protected groupNodes(members Collection<Member>, keyFunction Function<Member,String>) : Collection<MemberGroup> in class io.atomix.primitive.partition.MemberGroupStrategy |
From |
To |
|
Change Variable Type elector2 : AsyncLeaderElector<NodeId> to elector2 : AsyncLeaderElector<MemberId> in method public testRun() : void in class io.atomix.core.election.impl.LeaderElectorTest |
From |
To |
|
Change Variable Type nodes : Set<NodeId> to nodes : Set<MemberId> in method private sendAdvertisement(address Address) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Change Variable Type ephemeralNode : Node to ephemeralMember : Member in method public testClusterService() : void in class io.atomix.cluster.impl.DefaultClusterMembershipServiceTest |
From |
To |
|
Change Variable Type bootstrap : List<Node> to bootstrap : List<Member> in method private buildClusterMetadata(bootstrapNodes Integer...) : ClusterMetadata in class io.atomix.cluster.messaging.impl.DefaultClusterEventingServiceTest |
From |
To |
|
Change Variable Type node : Node to member : Member in method private doUnicast(subject String, payload byte[], toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Change Variable Type candidate : Member to candidate : GroupMember in method public backups(numBackups int) : List<GroupMember> in class io.atomix.primitive.partition.PrimaryTerm |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private handleBootstrap(memberId MemberId) : PartitionGroupInfo in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.backup.PrimaryBackupClient.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getEvent(listenerId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public RaftContext(name String, localMemberId MemberId, membershipService ClusterMembershipService, protocol RaftServerProtocol, storage RaftStorage, primitiveTypes PrimitiveTypeRegistry, threadModel ThreadModel, threadPoolSize int) in class io.atomix.protocols.raft.impl.RaftContext |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public digest(memberId MemberId) : NodeDigest in class io.atomix.cluster.impl.ClusterMetadataAdvertisement |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public CorePrimitivesService(executorService ScheduledExecutorService, membershipService ClusterMembershipService, communicationService ClusterMessagingService, eventService ClusterEventingService, partitionService PartitionService, config AtomixConfig) in class io.atomix.core.impl.CorePrimitivesService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public LocalRaftServerProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method protected address(memberId MemberId) : Address in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public DefaultRaftClient(clientId String, memberId MemberId, cluster Collection<MemberId>, protocol RaftClientProtocol, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.impl.DefaultRaftClient |
From |
To |
|
Rename Parameter nodeIds : Set<NodeId> to memberIds : Set<MemberId> in method public multicast(subject String, message M, memberIds Set<MemberId>) : void in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package InternalSubscriptionInfo(memberId MemberId, topic String, logicalTimestamp LogicalTimestamp) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService.InternalSubscriptionInfo |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public NodeEvent(memberId MemberId, type Type) in class io.atomix.rest.resources.ClusterResource.NodeEvent |
From |
To |
|
Rename Parameter nodes : Set<Node> to members : Set<Member> in method public NodeMemberGroup(groupId MemberGroupId, members Set<Member>) in class io.atomix.primitive.partition.impl.NodeMemberGroup |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Rename Parameter localNode : Node to localMember : Member in method public withLocalNode(localMember Member) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public HashBasedPrimaryElectionService(clusterMembershipService ClusterMembershipService, messagingService ClusterMessagingService) in class io.atomix.primitive.partition.impl.HashBasedPrimaryElectionService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method public getMemberGroup(member Member) : MemberGroup in class io.atomix.primitive.partition.MemberGroupService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public newClientProtocol(memberId MemberId) : PrimaryBackupClientProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocolFactory |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public addNodeListener(nodeId String, clusterMembershipService ClusterMembershipService, events EventManager) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter node : Node to member : Member in method public removeNode(member Member) : void in class io.atomix.cluster.ManagedPersistentMetadataService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<LocalRaftServerProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNode(clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter node : Node to member : Member in method private updateNode(member Member) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method private createServer(member Member, members List<Member>) : RaftServer in class io.atomix.protocols.raft.RaftPerformanceTest |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupProxy(clientName String, sessionId SessionId, primitiveType PrimitiveType, descriptor PrimitiveDescriptor, clusterMembershipService ClusterMembershipService, protocol PrimaryBackupClientProtocol, primaryElection PrimaryElection, threadContext ThreadContext) in class io.atomix.protocols.backup.proxy.PrimaryBackupProxy |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public PrimaryBackupSession(sessionId SessionId, memberId MemberId, context PrimaryBackupServiceContext) in class io.atomix.protocols.backup.impl.PrimaryBackupSession |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method private sendAndReceive(subject String, payload byte[], toMemberId MemberId, timeout Duration) : CompletableFuture<byte[]> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public getOrCreateSession(sessionId long, memberId MemberId) : PrimaryBackupSession in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public HashBasedPrimaryElection(partitionId PartitionId, clusterMembershipService ClusterMembershipService, electionService HashBasedPrimaryElectionService) in class io.atomix.primitive.partition.impl.HashBasedPrimaryElection |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method private buildPartitions(membershipService ClusterMembershipService) : Collection<PartitionMetadata> in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public heartbeat(memberId MemberId, request HeartbeatRequest) : CompletableFuture<HeartbeatResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method protected buildClusterEventService(membershipService ClusterMembershipService, messagingService MessagingService) : ManagedClusterEventingService in class io.atomix.cluster.AtomixCluster |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method protected buildClusterMessagingService(membershipService ClusterMembershipService, messagingService MessagingService) : ManagedClusterMessagingService in class io.atomix.cluster.AtomixCluster |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.raft.RaftServer.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method public removeNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, toMemberId MemberId) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public RaftProxyManager(clientId String, memberId MemberId, protocol RaftClientProtocol, selectorManager MemberSelectorManager, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.raft.proxy.impl.RaftProxyManager |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeInfo(nodeId String, clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter cluster : ClusterService to membershipService : ClusterMembershipService in method public DefaultClusterMessagingService(membershipService ClusterMembershipService, messagingService MessagingService) in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getEvent(clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultPartitionManagementService(membershipService ClusterMembershipService, communicationService ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry, electionService PrimaryElectionService, sessionIdService SessionIdService) in class io.atomix.primitive.partition.impl.DefaultPartitionManagementService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public close(memberId MemberId, request CloseRequest) : CompletableFuture<CloseResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public event(memberId MemberId, session SessionId, event PrimitiveEvent) : void in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private createServer(memberId MemberId) : PrimaryBackupServer in class io.atomix.protocols.backup.PrimaryBackupTest |
From |
To |
|
Rename Parameter nodeIds : Set<NodeId> to memberIds : Set<MemberId> in method public multicast(subject String, message M, encoder Function<M,byte[]>, memberIds Set<MemberId>) : void in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public CorePrimitiveManagementService(executorService ScheduledExecutorService, membershipService ClusterMembershipService, communicationService ClusterMessagingService, eventService ClusterEventingService, partitionService PartitionService, primitiveRegistry PrimitiveRegistry) in class io.atomix.core.impl.CorePrimitiveManagementService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.ClusterMembershipService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftPerformanceTest.TestMember |
From |
To |
|
Rename Parameter coreNodes : Node... to coreMembers : Member... in method public withNodes(coreMembers Member...) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public builder(localMemberId MemberId) : Builder in class io.atomix.protocols.raft.RaftServer |
From |
To |
|
Rename Parameter node : Node to member : Member in method private activateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public persistent(memberId MemberId, address Address) : Member in class io.atomix.cluster.Member |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public RaftPartitionClient(partition RaftPartition, localMemberId MemberId, protocol RaftClientProtocol) in class io.atomix.protocols.raft.partition.impl.RaftPartitionClient |
From |
To |
|
Rename Parameter bootstrapNodes : Node... to bootstrapMembers : Member... in method public withNodes(bootstrapMembers Member...) : Builder in class io.atomix.cluster.ClusterMetadata.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public newClientProtocol(memberId MemberId) : RaftClientProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocolFactory |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public removeNodeListener(nodeId String, listenerId String, clusterMembershipService ClusterMembershipService, events EventManager) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public addListener(clusterMembershipService ClusterMembershipService, events EventManager) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupClient(clientName String, clusterMembershipService ClusterMembershipService, protocol PrimaryBackupClientProtocol, primaryElection PrimaryElection, sessionIdService SessionIdService, threadContextFactory ThreadContextFactory) in class io.atomix.protocols.backup.PrimaryBackupClient |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public send(subject String, message M, encoder Function<M,byte[]>, decoder Function<byte[],R>, toMemberId MemberId, timeout Duration) : CompletableFuture<R> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method private doUnicast(subject String, payload byte[], toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultClusterEventingService(membershipService ClusterMembershipService, messagingService MessagingService) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public withMembershipService(membershipService ClusterMembershipService) : Builder in class io.atomix.protocols.backup.PrimaryBackupServer.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method protected sendAndReceive(memberId MemberId, type String, request T) : CompletableFuture<U> in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method public addNode(member Member) : void in class io.atomix.cluster.impl.DefaultPersistentMetadataService |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeEvent(nodeId String, listenerId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private onLeaderChange(memberId MemberId) : void in class io.atomix.protocols.raft.proxy.impl.DefaultRaftProxy |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method private validateMembership(membershipService ClusterMembershipService) : boolean in class io.atomix.protocols.raft.partition.RaftPartitionGroup |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package BackupQueue(memberId MemberId) in class io.atomix.protocols.backup.roles.SynchronousReplicator.BackupQueue |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package ClusterHeartbeat(memberId MemberId, type Member.Type, zone String, rack String, host String, tags Set<String>) in class io.atomix.cluster.impl.ClusterHeartbeat |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method private buildPartitionService(config AtomixConfig, clusterMembershipService ClusterMembershipService, messagingService ClusterMessagingService, primitiveTypeRegistry PrimitiveTypeRegistry) : ManagedPartitionService in class io.atomix.core.Atomix |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private getClient(memberId MemberId) : CompletableFuture<LocalRaftClientProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public newServerProtocol(memberId MemberId) : RaftServerProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocolFactory |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.protocol.PrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.cluster.AtomixCluster.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public configure(memberId MemberId, request ConfigureRequest) : CompletableFuture<ConfigureResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public vote(memberId MemberId, request VoteRequest) : CompletableFuture<VoteResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.partition.impl.RaftClientCommunicator |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method protected Builder(localMemberId MemberId) in class io.atomix.protocols.raft.RaftServer.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter coreNodes : Node... to coreMembers : Member... in method public withNodes(coreMembers Member...) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public poll(memberId MemberId, request PollRequest) : CompletableFuture<PollResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public LocalRaftClientProtocol(memberId MemberId, serializer Serializer, servers Map<MemberId,LocalRaftServerProtocol>, clients Map<MemberId,LocalRaftClientProtocol>) in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodes : Collection<Node> to members : Collection<Member> in method public ClusterMetadata(members Collection<Member>) in class io.atomix.cluster.ClusterMetadata |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public closeSession(memberId MemberId, request CloseSessionRequest) : CompletableFuture<CloseSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package BackupQueue(memberId MemberId) in class io.atomix.protocols.backup.roles.AsynchronousReplicator.BackupQueue |
From |
To |
|
Rename Parameter node : Node to member : Member in method private deactivateNode(member Member) : void in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Rename Parameter nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method protected sendAsync(memberId MemberId, type String, request Object) : CompletableFuture<Void> in class io.atomix.protocols.raft.protocol.RaftMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private getServer(memberId MemberId) : CompletableFuture<LocalRaftServerProtocol> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method public addNode(member Member) : void in class io.atomix.cluster.ManagedPersistentMetadataService |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultMemberGroupService(membershipService ClusterMembershipService, memberGroupProvider MemberGroupProvider) in class io.atomix.primitive.partition.impl.DefaultMemberGroupService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public newServerProtocol(memberId MemberId) : PrimaryBackupServerProtocol in class io.atomix.protocols.backup.protocol.TestPrimaryBackupProtocolFactory |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private createServer(memberId MemberId) : RaftServer in class io.atomix.protocols.raft.RaftTest |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public GroupMember(memberId MemberId, groupId MemberGroupId) in class io.atomix.primitive.partition.GroupMember |
From |
To |
|
Rename Parameter localNode : Node to localMember : Member in method public DefaultClusterMembershipService(localMember Member, bootstrapMetadataService BootstrapMetadataService, persistentMetadataService PersistentMetadataService, messagingService MessagingService, broadcastService BroadcastService) in class io.atomix.cluster.impl.DefaultClusterMembershipService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public Builder(localMemberId MemberId) in class io.atomix.protocols.raft.impl.DefaultRaftServer.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public append(memberId MemberId, request AppendRequest) : CompletableFuture<AppendResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodes(clusterMembershipService ClusterMembershipService) : Response in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter node : Node to member : Member in method package NodeInfo(member Member) in class io.atomix.rest.resources.ClusterResource.NodeInfo |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupServerContext(serverName String, clusterMembershipService ClusterMembershipService, memberGroupService ManagedMemberGroupService, protocol PrimaryBackupServerProtocol, threadContextFactory ThreadContextFactory, primitiveTypes PrimitiveTypeRegistry, primaryElection PrimaryElection) in class io.atomix.protocols.backup.impl.PrimaryBackupServerContext |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public removeListener(listenerId String, clusterMembershipService ClusterMembershipService, events EventManager) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodes : Collection<Node> to members : Collection<Member> in method public withNodes(members Collection<Member>) : Builder in class io.atomix.cluster.ClusterMetadata.Builder |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public RaftClusterContext(localMemberId MemberId, raft RaftContext) in class io.atomix.protocols.raft.cluster.impl.RaftClusterContext |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public createSession(sessionId long, memberId MemberId) : PrimaryBackupSession in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public command(memberId MemberId, request CommandRequest) : CompletableFuture<CommandResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public reconfigure(memberId MemberId, request ReconfigureRequest) : CompletableFuture<ReconfigureResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.RaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package client(memberId MemberId) : LocalRaftClientProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public withNodeId(memberId MemberId) : Builder in class io.atomix.protocols.raft.RaftClient.Builder |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public execute(memberId MemberId, request ExecuteRequest) : CompletableFuture<ExecuteResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupClientProtocol |
From |
To |
|
Rename Parameter node : Node to member : Member in method private bootstrap(member Member) : CompletableFuture<Void> in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Rename Parameter node : Node to member : Member in method public isMember(member Member) : boolean in class io.atomix.primitive.partition.impl.NodeMemberGroup |
From |
To |
|
Rename Parameter node : Node to member : Member in method public isMember(member Member) : boolean in class io.atomix.primitive.partition.MemberGroup |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public getNodeEvent(nodeId String, clusterMembershipService ClusterMembershipService, events EventManager, response AsyncResponse) : void in class io.atomix.rest.resources.ClusterResource |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public restore(memberId MemberId, request RestoreRequest) : CompletableFuture<RestoreResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public install(memberId MemberId, request InstallRequest) : CompletableFuture<InstallResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to clusterMembershipService : ClusterMembershipService in method public PrimaryBackupServiceContext(serverName String, primitiveId PrimitiveId, primitiveType PrimitiveType<?,?,?>, descriptor PrimitiveDescriptor, threadContext ThreadContext, clusterMembershipService ClusterMembershipService, memberGroupService MemberGroupService, protocol PrimaryBackupServerProtocol, primaryElection PrimaryElection) in class io.atomix.protocols.backup.service.impl.PrimaryBackupServiceContext |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public join(memberId MemberId, request JoinRequest) : CompletableFuture<JoinResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public openSession(memberId MemberId, request OpenSessionRequest) : CompletableFuture<OpenSessionResponse> in class io.atomix.protocols.raft.protocol.LocalRaftClientProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public keepAlive(memberId MemberId, request KeepAliveRequest) : CompletableFuture<KeepAliveResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public query(memberId MemberId, request QueryRequest) : CompletableFuture<QueryResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, encoder Function<M,byte[]>, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.impl.DefaultClusterMessagingService |
From |
To |
|
Rename Parameter localNode : Node to localMember : Member in method public withLocalNode(localMember Member) : Builder in class io.atomix.core.Atomix.Builder |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public DefaultPartitionService(membershipService ClusterMembershipService, messagingService ClusterMessagingService, primitiveTypeRegistry PrimitiveTypeRegistry, systemGroup ManagedPartitionGroup, groups Collection<ManagedPartitionGroup>) in class io.atomix.primitive.partition.impl.DefaultPartitionService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package InternalSubscriptionInfo(memberId MemberId, topic String, logicalTimestamp LogicalTimestamp, tombstone boolean) in class io.atomix.cluster.messaging.impl.DefaultClusterEventingService.InternalSubscriptionInfo |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.raft.partition.impl.RaftServerCommunicator |
From |
To |
|
Rename Parameter localNodeId : NodeId to localMemberId : MemberId in method public RaftPartitionServer(partition RaftPartition, localMemberId MemberId, membershipService ClusterMembershipService, clusterCommunicator ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry) in class io.atomix.protocols.raft.partition.impl.RaftPartitionServer |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public backup(memberId MemberId, request BackupRequest) : CompletableFuture<BackupResponse> in class io.atomix.protocols.backup.protocol.TestPrimaryBackupServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public leave(memberId MemberId, request LeaveRequest) : CompletableFuture<LeaveResponse> in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.RaftClientMessagingProtocol |
From |
To |
|
Rename Parameter toNodeId : NodeId to toMemberId : MemberId in method public unicast(subject String, message M, encoder Function<M,byte[]>, toMemberId MemberId) : CompletableFuture<Void> in class io.atomix.cluster.messaging.ClusterMessagingService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method private sendAndReceive(subject String, request T, memberId MemberId) : CompletableFuture<U> in class io.atomix.protocols.backup.partition.impl.PrimaryBackupServerCommunicator |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public metadata(memberId MemberId, request MetadataRequest) : CompletableFuture<MetadataResponse> in class io.atomix.protocols.raft.protocol.LocalRaftServerProtocol |
From |
To |
|
Rename Parameter clusterService : ClusterService to membershipService : ClusterMembershipService in method public RaftPartitionServer(partition RaftPartition, localMemberId MemberId, membershipService ClusterMembershipService, clusterCommunicator ClusterMessagingService, primitiveTypes PrimitiveTypeRegistry) in class io.atomix.protocols.raft.partition.impl.RaftPartitionServer |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftTest.TestMember |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public ephemeral(memberId MemberId, address Address) : Member in class io.atomix.cluster.Member |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public publish(memberId MemberId, request PublishRequest) : void in class io.atomix.protocols.raft.protocol.RaftServerMessagingProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public getMember(memberId MemberId) : Member in class io.atomix.cluster.TestClusterMembershipService |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public transfer(memberId MemberId, request TransferRequest) : CompletableFuture<TransferResponse> in class io.atomix.protocols.raft.protocol.RaftServerProtocol |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method public TestMember(memberId MemberId, type Type) in class io.atomix.protocols.raft.RaftFuzzTest.TestMember |
From |
To |
|
Rename Parameter nodeId : NodeId to memberId : MemberId in method package server(memberId MemberId) : LocalRaftServerProtocol in class io.atomix.protocols.raft.protocol.LocalRaftProtocol |
From |
To |