Package | Description |
---|---|
com.hazelcast.cache.impl.operation |
Hazelcast JSR-107 aka JCache implementation
|
com.hazelcast.client.cache.impl.nearcache.invalidation | |
com.hazelcast.client.connection |
Provides connection interfaces/classes for com.hazelcast.client
Everything in this package and its subpackages is private.
|
com.hazelcast.client.connection.nio |
Contains classes related to New IO for com.hazelcast.client.connection
|
com.hazelcast.client.impl |
Implementation classes of the com.hazelcast.client interfaces
|
com.hazelcast.client.impl.protocol.task |
Client tasks associated with requests.
|
com.hazelcast.client.impl.protocol.task.cache |
Client protocol tasks implementations for JCache
|
com.hazelcast.client.impl.protocol.task.crdt.pncounter | |
com.hazelcast.client.impl.protocol.task.executorservice |
Client protocol tasks implementations for ExecutorService
|
com.hazelcast.client.impl.protocol.task.scheduledexecutor | |
com.hazelcast.client.impl.querycache |
Contains query cache internal implementations for client side.
|
com.hazelcast.client.impl.querycache.subscriber |
Contains Hazelcast Enterprise version client-side query cache
subscriber implementation classes.
|
com.hazelcast.client.map.impl.nearcache.invalidation | |
com.hazelcast.client.proxy |
This package contains client side proxy implementations of the different Hazelcast data structures
and operation types
|
com.hazelcast.client.spi |
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
|
com.hazelcast.client.spi.impl |
Provides util classes for the Hazelcast client SPI.
|
com.hazelcast.client.spi.impl.discovery | |
com.hazelcast.cluster |
This package contains the cluster functionality.
|
com.hazelcast.cluster.impl | |
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.queue | |
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.cp |
Contains public APIs of the CP subsystem
|
com.hazelcast.cp.internal |
Contains implementation of the CP subsystem
|
com.hazelcast.cp.internal.datastructures.countdownlatch |
Contains service classes for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.countdownlatch.operation |
Contains operations for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.lock |
Contains service classes for the Raft-based
ILock
and FencedLock implementation |
com.hazelcast.cp.internal.datastructures.lock.operation |
Contains operations for the Raft-based
ILock implementation |
com.hazelcast.cp.internal.datastructures.semaphore |
Contains service classes for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.semaphore.operation |
Contains operations for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.spi.blocking |
Contains the interfaces and abstractions that are implemented / extended
by blocking Raft services, such as Lock, Semaphore, and CountDownLatch
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.session.operation |
Contains operations that are internally used by the CP session API
|
com.hazelcast.cp.session |
Contains session abstractions of the CP subsystem
|
com.hazelcast.crdt.pncounter |
This package contains the PN (Positive-Negative) CRDT counter
implementation.
|
com.hazelcast.hotrestart |
This package contains Hot Restart classes needed for open source Hazelcast code
|
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.cluster |
Contains the internals for cluster management like discovery, joining etc.
|
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.internal.management |
Contains classes to provide data/operation interface for Management Center.
|
com.hazelcast.internal.nearcache.impl.invalidation |
Invalidations for Near Cache.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.internal.partition.operation |
Contains the operations for partition package.
|
com.hazelcast.internal.util |
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
|
com.hazelcast.map.impl.event | |
com.hazelcast.map.impl.nearcache.invalidation | |
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.map.impl.querycache |
Contains query cache internal implementation classes.
|
com.hazelcast.map.impl.querycache.event |
This package contains classes for query cache events.
|
com.hazelcast.map.impl.recordstore | |
com.hazelcast.mapreduce |
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster. |
com.hazelcast.mapreduce.impl |
This package contains the default implementation for the map reduce framework
internals.
|
com.hazelcast.mapreduce.impl.notification |
This package contains all remote node notifications
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
com.hazelcast.monitor.impl |
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
|
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.nio.tcp |
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided. |
com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
com.hazelcast.replicatedmap |
Classes for replicated map.
|
com.hazelcast.replicatedmap.impl |
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally.
|
com.hazelcast.replicatedmap.impl.operation |
This package contains replicated map operations which are executed on remote nodes
|
com.hazelcast.scheduledexecutor |
This package contains ScheduledExecutorService functionality for Hazelcast.
|
com.hazelcast.scheduledexecutor.impl | |
com.hazelcast.spi |
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
|
com.hazelcast.spi.discovery |
This package contains the public SPI for vendors and users to implement their
custom node / IP discovery strategy.
|
com.hazelcast.spi.exception |
Contains exceptions for Hazelcast SPI.
|
com.hazelcast.spi.impl |
Contains implementations for Hazelcast SPI.
|
com.hazelcast.spi.impl.eventservice.impl |
Contains the code for the
InternalEventService implementation. |
com.hazelcast.spi.impl.operationexecutor.impl |
Contains the
OperationExecutorImpl code. |
com.hazelcast.spi.impl.operationservice |
Contains the
InternalOperationService API. |
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
com.hazelcast.spi.impl.operationservice.impl.operations |
Contains the Operations being used by the
OperationServiceImpl . |
com.hazelcast.spi.partition |
Contains the SPI for partition logic for Hazelcast.
|
com.hazelcast.topic.impl.reliable | |
com.hazelcast.transaction.impl |
Provides implementation for Hazelcast transaction support.
|
com.hazelcast.util |
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
|
Modifier and Type | Method and Description |
---|---|
void |
CachePutAllOperation.setTarget(Address address) |
void |
CacheMergeOperation.setTarget(Address address) |
Modifier and Type | Method and Description |
---|---|
protected InternalCompletableFuture |
ClientCacheInvalidationMetaDataFetcher.fetchMetadataOf(Address address,
List<String> names) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientConnectionManager.getOwnerConnectionAddress() |
Address |
AddressTranslator.translate(Address address)
Translates the given address to another address specific to
network or service
|
Modifier and Type | Method and Description |
---|---|
List<Address> |
Addresses.primary() |
List<Address> |
Addresses.secondary() |
Modifier and Type | Method and Description |
---|---|
abstract void |
ClientConnectionStrategy.beforeConnectToCluster(Address target)
If a cluster connection is established, this method will be called.
|
abstract void |
ClientConnectionStrategy.beforeGetConnection(Address target)
The purpose of this method is to validate a connection request by target, and exit the blocking invocation.
|
abstract void |
ClientConnectionStrategy.beforeOpenConnection(Address target)
If a new connection is required to open by
ClientConnectionManager ,
this method will be called. |
Connection |
ClientConnectionManager.getActiveConnection(Address address) |
Connection |
ClientConnectionManager.getOrConnect(Address address) |
Connection |
ClientConnectionManager.getOrTriggerConnect(Address address,
boolean acquiresResource) |
Address |
AddressTranslator.translate(Address address)
Translates the given address to another address specific to
network or service
|
Constructor and Description |
---|
Addresses(Collection<Address> primary) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientConnection.getEndPoint() |
Address |
ClientConnectionManagerImpl.getOwnerConnectionAddress() |
Address |
ClusterConnectorServiceImpl.getOwnerConnectionAddress() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultClientConnectionStrategy.beforeConnectToCluster(Address target) |
void |
DefaultClientConnectionStrategy.beforeGetConnection(Address target) |
void |
DefaultClientConnectionStrategy.beforeOpenConnection(Address target) |
protected ClientConnection |
ClientConnectionManagerImpl.createSocketConnection(Address remoteAddress) |
Connection |
ClientConnectionManagerImpl.getActiveConnection(Address target) |
Connection |
ClientConnectionManagerImpl.getOrConnect(Address address) |
Connection |
ClientConnectionManagerImpl.getOrConnect(Address address,
boolean asOwner) |
Connection |
ClientConnectionManagerImpl.getOrTriggerConnect(Address target,
boolean acquiresResources) |
void |
ClusterConnectorServiceImpl.setOwnerConnectionAddress(Address ownerConnectionAddress) |
void |
ClientConnection.setRemoteEndpoint(Address remoteEndpoint) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientEngineImpl.clientAddressOf(Address memberAddress) |
Address |
ClientEngine.clientAddressOf(Address memberAddress)
Locates the client address of the given member address.
|
Address |
NoOpClientEngine.clientAddressOf(Address clientAddress) |
Address |
ClientEngineImpl.getThisAddress() |
Address |
ClientEngine.getThisAddress() |
Address |
NoOpClientEngine.getThisAddress() |
Address |
ClientEngineImpl.memberAddressOf(Address clientAddress) |
Address |
ClientEngine.memberAddressOf(Address clientAddress)
Locates the cluster member that has the provided client address and returns its member address,
to be used for intra-cluster communication.
|
Address |
NoOpClientEngine.memberAddressOf(Address clientAddress) |
Modifier and Type | Method and Description |
---|---|
Collection<Map.Entry<Address,List<Integer>>> |
ClientPartitionListenerService.getPartitions(PartitionTableView partitionTableView)
If any partition does not have an owner, this method returns empty collection
|
Modifier and Type | Method and Description |
---|---|
Address |
ClientEngineImpl.clientAddressOf(Address memberAddress) |
Address |
ClientEngine.clientAddressOf(Address memberAddress)
Locates the client address of the given member address.
|
Address |
NoOpClientEngine.clientAddressOf(Address clientAddress) |
Address |
ClientEngineImpl.memberAddressOf(Address clientAddress) |
Address |
ClientEngine.memberAddressOf(Address clientAddress)
Locates the cluster member that has the provided client address and returns its member address,
to be used for intra-cluster communication.
|
Address |
NoOpClientEngine.memberAddressOf(Address clientAddress) |
Constructor and Description |
---|
MemberImpl(Address address,
MemberVersion version) |
MemberImpl(Address address,
MemberVersion version,
String uuid) |
MemberImpl(Address address,
MemberVersion version,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
MemberImpl(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
Modifier and Type | Method and Description |
---|---|
protected abstract Address |
AbstractAddressMessageTask.getAddress() |
Modifier and Type | Method and Description |
---|---|
protected ClientMessage |
AuthenticationMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte version,
List<Member> cleanedUpMembers,
int partitionCount,
String clusterId) |
protected abstract ClientMessage |
AuthenticationBaseMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte serializationVersion,
List<Member> cleanedUpMembers,
int partitionCount,
String clusterId) |
protected ClientMessage |
AuthenticationCustomCredentialsMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte version,
List<Member> cleanedUpMembers,
int partitionCount,
String clusterId) |
Modifier and Type | Method and Description |
---|---|
protected Address |
CacheGetConfigMessageTask.getAddress() |
Modifier and Type | Method and Description |
---|---|
protected Address |
PNCounterGetMessageTask.getAddress() |
protected Address |
PNCounterAddMessageTask.getAddress() |
Modifier and Type | Method and Description |
---|---|
protected Address |
ExecutorServiceCancelOnAddressMessageTask.getAddress() |
Modifier and Type | Method and Description |
---|---|
protected Address |
ScheduledExecutorTaskDisposeFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorSubmitToAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskIsDoneFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskGetDelayFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskGetResultFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskGetStatisticsFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskCancelFromAddressMessageTask.getAddress() |
protected Address |
ScheduledExecutorTaskIsCancelledFromAddressMessageTask.getAddress() |
Modifier and Type | Method and Description |
---|---|
Address |
ClientQueryCacheContext.getThisNodesAddress() |
Modifier and Type | Method and Description |
---|---|
Future |
ClientInvokerWrapper.invokeOnTarget(Object request,
Address address) |
Modifier and Type | Method and Description |
---|---|
protected InternalCompletableFuture |
ClientMapInvalidationMetaDataFetcher.fetchMetadataOf(Address address,
List<String> names) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientPNCounterProxy.getCurrentTargetReplicaAddress()
Returns the current target replica address to which this proxy is
sending invocations.
|
Modifier and Type | Method and Description |
---|---|
Address |
ProxyManager.findNextAddressToSendCreateRequest() |
Address |
ClientClusterService.getMasterAddress()
Returns the address of the master member.
|
Address |
ClientPartitionService.getPartitionOwner(int partitionId) |
Modifier and Type | Method and Description |
---|---|
Member |
ClientClusterService.getMember(Address address)
Gets the member for the given address.
|
protected <T> T |
ClientProxy.invokeOnAddress(ClientMessage clientMessage,
Address address) |
void |
ClientInvocationService.invokeOnTarget(ClientInvocation invocation,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientClusterServiceImpl.getMasterAddress() |
Address |
ClientPartitionServiceImpl.getPartitionOwner(int partitionId) |
Address |
DefaultAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
Member |
ClientClusterServiceImpl.getMember(Address address) |
void |
NonSmartClientInvocationService.invokeOnTarget(ClientInvocation invocation,
Address target) |
void |
SmartClientInvocationService.invokeOnTarget(ClientInvocation invocation,
Address target) |
Address |
DefaultAddressTranslator.translate(Address address) |
Constructor and Description |
---|
ClientInvocation(HazelcastClientInstanceImpl client,
ClientMessage clientMessage,
String objectName,
Address address)
Create an invocation that will be executed on member with given
address . |
ClientInvocation(HazelcastClientInstanceImpl client,
ClientMessage clientMessage,
String objectName,
int partitionId,
Address address,
Connection connection) |
Modifier and Type | Method and Description |
---|---|
Address |
DiscoveryAddressTranslator.translate(Address address) |
Address |
HazelcastCloudAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
DiscoveryAddressTranslator.translate(Address address) |
Address |
HazelcastCloudAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
void |
Joiner.blacklist(Address address,
boolean permanent)
Deprecated.
Adds an address to the blacklist.
|
boolean |
Joiner.isBlacklisted(Address address)
Deprecated.
Checks if an address is blacklisted.
|
void |
Joiner.setTargetAddress(Address targetAddress)
Deprecated.
|
boolean |
Joiner.unblacklist(Address address)
Deprecated.
Removes an address from the blacklist if it is temporarily blacklisted.
|
Modifier and Type | Method and Description |
---|---|
protected Collection<Address> |
TcpIpJoiner.getPossibleAddresses() |
protected Collection<Address> |
TcpIpJoiner.getPossibleAddressesForInitialJoin() |
Modifier and Type | Method and Description |
---|---|
Address |
CollectionEvent.getCaller() |
Constructor and Description |
---|
CollectionEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
Constructor and Description |
---|
QueueEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
Modifier and Type | Method and Description |
---|---|
Address |
Member.getAddress()
Returns the Address of this Member.
|
Modifier and Type | Method and Description |
---|---|
Map<EndpointQualifier,Address> |
Member.getAddressMap() |
Modifier and Type | Method and Description |
---|---|
Address |
CPMember.getAddress()
Returns the address of this CP member.
|
Modifier and Type | Method and Description |
---|---|
Address |
CPMemberInfo.getAddress() |
Modifier and Type | Method and Description |
---|---|
void |
CallerAware.setCaller(Address callerAddress,
long callId)
Sets the caller information on the Raft op
|
Constructor and Description |
---|
CPMemberInfo(UUID uuid,
Address address) |
Constructor and Description |
---|
AwaitInvocationKey(long commitIndex,
UUID invocationUid,
Address callerAddress,
long callId) |
Modifier and Type | Method and Description |
---|---|
void |
AwaitOp.setCaller(Address callerAddress,
long callId) |
Constructor and Description |
---|
LockInvocationKey(long commitIndex,
UUID invocationUid,
Address callerAddress,
long callId,
LockEndpoint endpoint) |
Modifier and Type | Method and Description |
---|---|
void |
LockOp.setCaller(Address callerAddress,
long callId) |
void |
TryLockOp.setCaller(Address callerAddress,
long callId) |
Constructor and Description |
---|
AcquireInvocationKey(long commitIndex,
UUID invocationUid,
Address callerAddress,
long callId,
SemaphoreEndpoint endpoint,
int permits) |
Modifier and Type | Method and Description |
---|---|
void |
AcquirePermitsOp.setCaller(Address callerAddress,
long callId) |
Modifier and Type | Field and Description |
---|---|
protected Address |
WaitKey.callerAddress |
Modifier and Type | Method and Description |
---|---|
Address |
WaitKey.callerAddress()
Returns address of the caller which created this wait key
|
Modifier and Type | Method and Description |
---|---|
Collection<Tuple2<Address,Long>> |
ResourceRegistry.getLiveOperations() |
Collection<Tuple2<Address,Long>> |
AbstractBlockingService.getLiveOperations(CPGroupId groupId) |
Constructor and Description |
---|
WaitKey(long commitIndex,
UUID invocationUid,
Address callerAddress,
long callId) |
Modifier and Type | Method and Description |
---|---|
Address |
CPSessionInfo.endpoint() |
Modifier and Type | Method and Description |
---|---|
SessionResponse |
RaftSessionService.createNewSession(CPGroupId groupId,
Address endpoint,
String endpointName,
CPSession.CPSessionOwnerType endpointType) |
Constructor and Description |
---|
CreateSessionOp(Address endpoint,
String endpointName,
CPSession.CPSessionOwnerType endpointType) |
Modifier and Type | Method and Description |
---|---|
Address |
CPSession.endpoint()
Returns the endpoint that has created this session
|
Modifier and Type | Method and Description |
---|---|
Address |
PNCounterProxy.getCurrentTargetReplicaAddress()
Returns the current target replica address to which this proxy is
sending invocations.
|
Modifier and Type | Method and Description |
---|---|
void |
NoopInternalHotRestartService.handleExcludedMemberUuids(Address sender,
Set<String> excludedMemberUuids) |
void |
InternalHotRestartService.handleExcludedMemberUuids(Address sender,
Set<String> excludedMemberUuids)
Handles the UUID set of excluded members only if this member is also excluded, and triggers the member force start process.
|
boolean |
NoopInternalHotRestartService.isMemberExcluded(Address memberAddress,
String memberUuid) |
boolean |
InternalHotRestartService.isMemberExcluded(Address memberAddress,
String memberUuid)
Checks if the given member has been excluded during the cluster start or not.
|
void |
NoopInternalHotRestartService.notifyExcludedMember(Address memberAddress) |
void |
InternalHotRestartService.notifyExcludedMember(Address memberAddress)
Notifies the excluded member and triggers the member force start process.
|
Modifier and Type | Field and Description |
---|---|
Address |
Node.address
Member-to-member address only.
|
protected Address |
AbstractMember.address |
Modifier and Type | Field and Description |
---|---|
protected Map<EndpointQualifier,Address> |
AbstractMember.addressMap |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractMember.getAddress() |
Address |
AddressPicker.getBindAddress()
Deprecated.
use
getBindAddress(EndpointQualifier.MEMBER instead |
Address |
AddressPicker.getBindAddress(EndpointQualifier qualifier)
Returns a server socket listener address.
|
Address |
Node.getMasterAddress() |
Address |
AddressPicker.getPublicAddress()
Deprecated.
use
getPublicAddress(EndpointQualifier.MEMBER instead |
Address |
AddressPicker.getPublicAddress(EndpointQualifier qualifier)
Returns a public address to be advertised to other cluster members and clients.
|
Address |
Node.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Map<EndpointQualifier,Address> |
AbstractMember.getAddressMap() |
Map<EndpointQualifier,Address> |
AddressPicker.getPublicAddressMap() |
Modifier and Type | Method and Description |
---|---|
String |
DefaultNodeExtension.createMemberUuid(Address address) |
String |
NodeExtension.createMemberUuid(Address address)
Creates a UUID for local member
|
Constructor and Description |
---|
Builder(Address address) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember,
String uuid) |
Constructor and Description |
---|
AbstractMember(Map<EndpointQualifier,Address> addresses,
MemberVersion version,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
Builder(Map<EndpointQualifier,Address> addresses) |
Modifier and Type | Method and Description |
---|---|
Address |
MemberInfo.getAddress() |
Address |
ClusterService.getMasterAddress()
Returns the address of the master member.
|
Address |
ClusterService.getThisAddress()
Gets the address of this member.
|
Modifier and Type | Method and Description |
---|---|
Map<EndpointQualifier,Address> |
MemberInfo.getAddressMap() |
Modifier and Type | Method and Description |
---|---|
MemberImpl |
ClusterService.getMember(Address address)
Gets the member for the given address.
|
MemberImpl |
ClusterService.getMember(Address address,
String uuid)
Gets the member with the given UUID and address.
|
Constructor and Description |
---|
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember,
MemberVersion version,
int memberListJoinVersion,
Map<EndpointQualifier,Address> addressMap) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember,
MemberVersion version,
Map<EndpointQualifier,Address> addressMap) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
MemberVersion version) |
Constructor and Description |
---|
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember,
MemberVersion version,
int memberListJoinVersion,
Map<EndpointQualifier,Address> addressMap) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember,
MemberVersion version,
Map<EndpointQualifier,Address> addressMap) |
Modifier and Type | Field and Description |
---|---|
protected Address |
JoinMessage.address |
Modifier and Type | Field and Description |
---|---|
protected ConcurrentMap<Address,Boolean> |
AbstractJoiner.blacklistedAddresses |
protected Collection<Address> |
JoinMessage.memberAddresses |
Modifier and Type | Method and Description |
---|---|
Address |
JoinMessage.getAddress() |
Address |
BindMessage.getLocalAddress() |
Address |
ClusterServiceImpl.getMasterAddress() |
Address |
MembersViewMetadata.getMasterAddress() |
Address |
MembersViewMetadata.getMemberAddress() |
Address |
ClusterStateTransactionLogRecord.getTarget() |
protected Address |
AbstractJoiner.getTargetAddress() |
Address |
ExtendedBindMessage.getTargetAddress() |
Address |
BindMessage.getTargetAddress() |
Address |
ClusterServiceImpl.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Set<Address> |
MembersView.getAddresses() |
Map<ProtocolType,Collection<Address>> |
ExtendedBindMessage.getLocalAddresses() |
Collection<Address> |
ClusterServiceImpl.getMemberAddresses() |
Collection<Address> |
JoinMessage.getMemberAddresses() |
protected Collection<Address> |
DiscoveryJoiner.getPossibleAddresses() |
protected Collection<Address> |
DiscoveryJoiner.getPossibleAddressesForInitialJoin() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractJoiner.blacklist(Address address,
boolean permanent) |
void |
ClusterStateManager.commitClusterState(ClusterStateChange stateChange,
Address initiator,
String txnId,
boolean isTransient) |
boolean |
MembersView.containsAddress(Address address) |
boolean |
MembersView.containsMember(Address address,
String uuid) |
static MulticastService |
MulticastService.createMulticastService(Address bindAddress,
Node node,
Config config,
ILogger logger) |
boolean |
ClusterServiceImpl.finalizeJoin(MembersView membersView,
Address callerAddress,
String callerUuid,
String targetUuid,
String clusterId,
ClusterState clusterState,
Version clusterVersion,
long clusterStartTime,
long masterTime,
OnJoinOp preJoinOp) |
MemberInfo |
MembersView.getMember(Address address) |
MemberImpl |
ClusterServiceImpl.getMember(Address address) |
MemberImpl |
MembershipManager.getMember(Address address) |
MemberImpl |
ClusterServiceImpl.getMember(Address address,
String uuid) |
MemberImpl |
MembershipManager.getMember(Address address,
String uuid) |
void |
ClusterServiceImpl.handleExplicitSuspicion(MembersViewMetadata expectedMembersViewMetadata,
Address suspectedAddress) |
void |
ClusterServiceImpl.handleExplicitSuspicionTrigger(Address caller,
int callerMemberListVersion,
MembersViewMetadata suspectedMembersViewMetadata) |
void |
ClusterJoinManager.handleMasterResponse(Address masterAddress,
Address callerAddress)
Set master address, if required.
|
MembersView |
ClusterServiceImpl.handleMastershipClaim(Address candidateAddress,
String candidateUuid) |
boolean |
AbstractJoiner.isBlacklisted(Address address) |
boolean |
ClusterServiceImpl.isMissingMember(Address address,
String uuid)
Returns whether member with given identity (either
UUID or Address
depending on Hot Restart is enabled or not) is a known missing member or not. |
void |
ClusterStateManager.lockClusterState(ClusterStateChange stateChange,
Address initiator,
String txnId,
long leaseTime,
int memberListVersion,
int partitionStateVersion)
Validates the requested cluster state change and sets a
ClusterStateLock . |
void |
ClusterServiceImpl.merge(Address newTargetAddress) |
MembersView |
MembershipManager.promoteToDataMember(Address address,
String uuid) |
boolean |
ClusterJoinManager.sendJoinRequest(Address toAddress,
boolean withCredentials)
Send join request to
toAddress . |
boolean |
ClusterJoinManager.sendMasterQuestion(Address toAddress)
Send a
WhoisMasterOp to designated address. |
void |
MembershipManager.sendMemberListToMember(Address target)
Sends the current member list to the
target . |
protected SplitBrainJoinMessage.SplitBrainMergeCheckResult |
AbstractJoiner.sendSplitBrainJoinMessageAndCheckResponse(Address target,
SplitBrainJoinMessage request)
Sends a split brain join request to the target address and checks the response to see if this node should merge
to the target address.
|
boolean |
ClusterServiceImpl.setMasterAddressToJoin(Address master) |
void |
AbstractJoiner.setTargetAddress(Address targetAddress) |
protected void |
AbstractJoiner.startClusterMerge(Address targetAddress,
int expectedMemberListVersion) |
void |
ClusterServiceImpl.suspectAddressIfNotConnected(Address address) |
boolean |
AbstractJoiner.unblacklist(Address address) |
boolean |
ClusterServiceImpl.updateMembers(MembersView membersView,
Address callerAddress,
String callerUuid,
String targetUuid) |
Constructor and Description |
---|
BindMessage(Address localAddress,
Address targetAddress,
boolean reply) |
ClusterStateTransactionLogRecord(ClusterStateChange stateChange,
Address initiator,
Address target,
String txnId,
long leaseTime,
int memberListVersion,
int partitionStateVersion,
boolean isTransient) |
ExtendedBindMessage(byte schemaVersion,
Map<ProtocolType,Collection<Address>> localAddresses,
Address targetAddress,
boolean reply) |
JoinMessage(byte packetVersion,
int buildNumber,
MemberVersion memberVersion,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck) |
JoinMessage(byte packetVersion,
int buildNumber,
MemberVersion memberVersion,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount) |
JoinRequest(byte packetVersion,
int buildNumber,
MemberVersion version,
Address address,
String uuid,
boolean liteMember,
ConfigCheck config,
Credentials credentials,
Map<String,Object> attributes,
Set<String> excludedMemberUuids,
Map<EndpointQualifier,Address> addresses) |
MembersViewMetadata(Address memberAddress,
String memberUuid,
Address masterAddress,
int memberListVersion) |
SplitBrainJoinMessage(byte packetVersion,
int buildNumber,
MemberVersion version,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount,
Version clusterVersion,
int memberListVersion) |
Constructor and Description |
---|
ExtendedBindMessage(byte schemaVersion,
Map<ProtocolType,Collection<Address>> localAddresses,
Address targetAddress,
boolean reply) |
JoinMessage(byte packetVersion,
int buildNumber,
MemberVersion memberVersion,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount) |
JoinRequest(byte packetVersion,
int buildNumber,
MemberVersion version,
Address address,
String uuid,
boolean liteMember,
ConfigCheck config,
Credentials credentials,
Map<String,Object> attributes,
Set<String> excludedMemberUuids,
Map<EndpointQualifier,Address> addresses) |
SplitBrainJoinMessage(byte packetVersion,
int buildNumber,
MemberVersion version,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount,
Version clusterVersion,
int memberListVersion) |
Modifier and Type | Field and Description |
---|---|
protected Address |
MasterResponseOp.masterAddress |
Modifier and Type | Method and Description |
---|---|
Address |
MasterResponseOp.getMasterAddress() |
Modifier and Type | Method and Description |
---|---|
void |
OnJoinOp.setTarget(Address address) |
void |
FinalizeJoinOp.setTarget(Address address) |
Constructor and Description |
---|
CommitClusterStateOp(ClusterStateChange stateChange,
Address initiator,
String txnId,
boolean isTransient) |
LockClusterStateOp(ClusterStateChange stateChange,
Address initiator,
String txnId,
long leaseTime,
int memberListVersion,
int partitionStateVersion) |
MasterResponseOp(Address originAddress) |
MergeClustersOp(Address newTargetAddress) |
RollbackClusterStateOp(Address initiator,
String txnId) |
Modifier and Type | Method and Description |
---|---|
InternalCompletableFuture<Object> |
ManagementCenterService.callOnAddress(Address address,
Operation operation) |
void |
ManagementCenterService.send(Address address,
Operation operation) |
Modifier and Type | Method and Description |
---|---|
protected abstract InternalCompletableFuture |
InvalidationMetaDataFetcher.fetchMetadataOf(Address address,
List<String> names) |
Modifier and Type | Method and Description |
---|---|
Address |
PartitionReplica.address() |
Address |
MigrationInfo.getDestinationAddress() |
Address |
PartitionRuntimeState.getMaster() |
Address |
MigrationInfo.getMaster() |
Address |
MigrationInfo.getSourceAddress() |
Modifier and Type | Method and Description |
---|---|
List<Integer> |
InternalPartitionService.getMemberPartitionsIfAssigned(Address target)
Returns partition ID list assigned to given target if partitions are assigned when method is called.
|
void |
PartitionRuntimeState.setMaster(Address master) |
MigrationInfo |
MigrationInfo.setMaster(Address master) |
void |
ReplicaFragmentMigrationState.setTarget(Address address) |
Constructor and Description |
---|
PartitionReplica(Address address,
String uuid) |
Modifier and Type | Method and Description |
---|---|
Address |
PartitionReplicaChangeEvent.getNewAddress() |
Address |
PartitionReplicaChangeEvent.getOldAddress() |
Address |
InternalPartitionImpl.getOwnerOrNull() |
Address |
InternalPartitionServiceImpl.getPartitionOwner(int partitionId) |
Address |
InternalPartitionServiceImpl.getPartitionOwnerOrWait(int partitionId) |
Address |
InternalPartitionImpl.getReplicaAddress(int replicaIndex) |
Modifier and Type | Method and Description |
---|---|
Map<Address,List<Integer>> |
InternalPartitionServiceImpl.getMemberPartitionsMap() |
Modifier and Type | Method and Description |
---|---|
boolean |
InternalPartitionServiceImpl.applyCompletedMigrations(Collection<MigrationInfo> migrations,
Address sender) |
boolean |
InternalPartitionServiceImpl.commitMigrationOnDestination(MigrationInfo migration,
Address sender) |
List<Integer> |
InternalPartitionServiceImpl.getMemberPartitions(Address target) |
List<Integer> |
InternalPartitionServiceImpl.getMemberPartitionsIfAssigned(Address target) |
boolean |
InternalPartitionServiceImpl.isMemberMaster(Address address)
Returns true only if the member is the last known master by
InternalPartitionServiceImpl and ClusterServiceImpl . |
boolean |
InternalPartitionImpl.isOwnerOrBackup(Address address) |
Constructor and Description |
---|
PartitionReplicaChangeEvent(int partitionId,
int replicaIndex,
Address oldAddress,
Address newAddress) |
Modifier and Type | Method and Description |
---|---|
void |
PartitionReplicaSyncResponse.setTarget(Address address) |
void |
MigrationOperation.setTarget(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
LockGuard.getLockOwner() |
Constructor and Description |
---|
LockGuard(Address lockOwner,
String lockOwnerId,
long leaseTime) |
Modifier and Type | Method and Description |
---|---|
Address |
EventData.getCaller() |
Modifier and Type | Method and Description |
---|---|
EntryEventData |
EntryEventDataCache.getOrCreateEventData(String mapName,
Address caller,
Data dataKey,
Object newValue,
Object oldValue,
Object mergingValue,
int eventType,
boolean includingValues)
If an
EntryEventData for the given parameters is already cached then return the cached value, otherwise create,
cache and return the EntryEventData . |
void |
QueryCacheEventPublisher.hintMapEvent(Address caller,
String mapName,
EntryEventType eventType,
int numberOfEntriesAffected,
int partitionId) |
void |
MapEventPublisherImpl.hintMapEvent(Address caller,
String mapName,
EntryEventType eventType,
int numberOfEntriesAffected,
int partitionId) |
void |
MapEventPublisher.hintMapEvent(Address caller,
String mapName,
EntryEventType eventType,
int numberOfEntriesAffected,
int partitionId)
Only gives a hint which indicates that a map-wide
operation has just been executed on this partition.
|
void |
MapEventPublisherImpl.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object oldValue,
Object dataValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object oldValue,
Object dataValue)
Publish an event to the event subsystem.
|
void |
MapEventPublisherImpl.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object oldValue,
Object value,
Object mergingValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object oldValue,
Object dataValue,
Object dataMergingValue)
Publish an event to the event subsystem.
|
void |
MapEventPublisherImpl.publishMapEvent(Address caller,
String mapName,
EntryEventType eventType,
int numberOfEntriesAffected) |
void |
MapEventPublisher.publishMapEvent(Address caller,
String mapName,
EntryEventType eventType,
int numberOfEntriesAffected) |
void |
MapEventPublisherImpl.publishMapPartitionLostEvent(Address caller,
String mapName,
int partitionId) |
void |
MapEventPublisher.publishMapPartitionLostEvent(Address caller,
String mapName,
int partitionId) |
Constructor and Description |
---|
EntryEventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
Data dataMergingValue,
int eventType) |
EntryEventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
int eventType) |
MapEventData(String source,
String mapName,
Address caller,
int eventType,
int numberOfEntries) |
MapPartitionEventData(String source,
String mapName,
Address caller,
int partitionId) |
Modifier and Type | Method and Description |
---|---|
protected InternalCompletableFuture |
MemberMapInvalidationMetaDataFetcher.fetchMetadataOf(Address address,
List<String> names) |
Modifier and Type | Method and Description |
---|---|
void |
PostJoinMapOperation.setTarget(Address address) |
void |
AddIndexBackupOperation.setTarget(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
NodeQueryCacheContext.getThisNodesAddress() |
Address |
QueryCacheContext.getThisNodesAddress()
Returns this nodes address.
|
Modifier and Type | Method and Description |
---|---|
Future |
InvokerWrapper.invokeOnTarget(Object operation,
Address address) |
Future |
NodeInvokerWrapper.invokeOnTarget(Object operation,
Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
LocalEntryEventData.getCaller() |
Address |
DefaultQueryCacheEventData.getCaller() |
Address |
LocalCacheWideEventData.getCaller() |
Address |
BatchEventData.getCaller() |
Modifier and Type | Field and Description |
---|---|
protected Address |
AbstractEvictableRecordStore.thisAddress |
Modifier and Type | Method and Description |
---|---|
boolean |
RecordStore.containsKey(Data dataKey,
Address callerAddress) |
boolean |
DefaultRecordStore.containsKey(Data key,
Address callerAddress) |
Object |
RecordStore.get(Data dataKey,
boolean backup,
Address callerAddress)
|
Object |
AbstractEvictableRecordStore.get(Data dataKey,
boolean backup,
Address callerAddress) |
Object |
RecordStore.get(Data dataKey,
boolean backup,
Address callerAddress,
boolean touch)
Gets record from
RecordStore . |
Object |
DefaultRecordStore.get(Data key,
boolean backup,
Address callerAddress,
boolean touch) |
MapEntries |
RecordStore.getAll(Set<Data> keySet,
Address callerAddress) |
MapEntries |
DefaultRecordStore.getAll(Set<Data> keys,
Address callerAddress) |
protected Map<Data,Object> |
DefaultRecordStore.loadEntries(Set<Data> keys,
Address callerAddress) |
Record |
RecordStore.loadRecordOrNull(Data key,
boolean backup,
Address callerAddress) |
Record |
DefaultRecordStore.loadRecordOrNull(Data key,
boolean backup,
Address callerAddress) |
Object |
RecordStore.putFromLoad(Data key,
Object value,
Address callerAddress)
Puts key-value pair to map which is the result of a load from map store operation.
|
Object |
DefaultRecordStore.putFromLoad(Data key,
Object value,
Address callerAddress) |
Object |
RecordStore.putIfAbsent(Data dataKey,
Object value,
long ttl,
long maxIdle,
Address callerAddress) |
Object |
DefaultRecordStore.putIfAbsent(Data key,
Object value,
long ttl,
long maxIdle,
Address callerAddress) |
Modifier and Type | Method and Description |
---|---|
Address |
JobPartitionState.getOwner()
Deprecated.
Returns the owner of this partition
|
Modifier and Type | Method and Description |
---|---|
Address |
MapReduceService.getKeyMember(Object key) |
Address |
MapReduceService.getLocalAddress() |
Modifier and Type | Method and Description |
---|---|
static <V> V |
MapReduceUtil.executeOperation(Operation operation,
Address address,
MapReduceService mapReduceService,
NodeEngine nodeEngine) |
<R> R |
MapReduceService.processRequest(Address address,
ProcessingOperation processingOperation) |
boolean |
MapReduceService.registerJobSupervisorCancellation(String name,
String jobId,
Address jobOwner) |
void |
MapReduceService.sendNotification(Address address,
MapReduceNotification notification) |
static JobPartitionState.State |
MapReduceUtil.stateChange(Address owner,
int partitionId,
JobPartitionState.State currentState,
JobProcessInformationImpl processInformation,
JobTaskConfiguration configuration) |
Modifier and Type | Method and Description |
---|---|
boolean |
MapReduceService.checkAssignedMembersAvailable(Collection<Address> assignedMembers) |
Modifier and Type | Method and Description |
---|---|
Address |
MemberAwareMapReduceNotification.getAddress() |
Address |
LastChunkNotification.getSender() |
Constructor and Description |
---|
IntermediateChunkNotification(Address address,
String name,
String jobId,
Map<KeyOut,Value> chunk,
int partitionId) |
LastChunkNotification(Address address,
String name,
String jobId,
Address sender,
int partitionId,
Map<KeyOut,Value> chunk) |
MemberAwareMapReduceNotification(Address address,
String name,
String jobId) |
ReducingFinishedNotification(Address address,
String name,
String jobId,
int partitionId) |
Modifier and Type | Method and Description |
---|---|
Map<Object,Address> |
KeysAssignmentResult.getAssignment() |
Constructor and Description |
---|
KeysAssignmentResult(RequestPartitionResult.ResultState resultState,
Map<Object,Address> assignment) |
Modifier and Type | Method and Description |
---|---|
Address |
JobSupervisor.assignKeyReducerAddress(Object key) |
Address |
JobTaskConfiguration.getJobOwner() |
Address |
JobSupervisor.getJobOwner() |
Address |
JobPartitionStateImpl.getOwner() |
Address |
JobSupervisor.getReducerAddressByKey(Object key) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
JobSupervisor.getReducerEventInterests(int partitionId) |
static <K,V> Map<Address,Map<K,V>> |
MapCombineTask.mapResultToMember(JobSupervisor supervisor,
Map<K,V> result) |
Modifier and Type | Method and Description |
---|---|
boolean |
JobSupervisor.assignKeyReducerAddress(Object key,
Address address) |
int |
MemberAssigningJobProcessInformationImpl.assignMemberId(Address address,
String memberUuid,
JobTaskConfiguration configuration) |
void |
JobSupervisor.notifyRemoteException(Address remoteAddress,
Throwable throwable) |
void |
ReducerTask.processChunk(int partitionId,
Address sender,
Map<Key,Chunk> chunk) |
Modifier and Type | Method and Description |
---|---|
void |
JobSupervisor.registerReducerEventInterests(int partitionId,
Set<Address> remoteReducers) |
Constructor and Description |
---|
JobPartitionStateImpl(Address address,
JobPartitionState.State state) |
JobTaskConfiguration(Address jobOwner,
NodeEngine nodeEngine,
int chunkSize,
String name,
String jobId,
Mapper mapper,
CombinerFactory combinerFactory,
ReducerFactory reducerFactory,
KeyValueSource keyValueSource,
boolean communicateStats,
TopologyChangedStrategy topologyChangedStrategy) |
Modifier and Type | Method and Description |
---|---|
Map<EndpointQualifier,Address> |
MemberStateImpl.getEndpoints() |
Modifier and Type | Method and Description |
---|---|
void |
MemberStateImpl.setEndpoints(Map<EndpointQualifier,Address> addressMap) |
Modifier and Type | Method and Description |
---|---|
Address |
Connection.getEndPoint()
Gets the
Address of the other side of this Connection. |
Address |
NodeIOService.getThisAddress() |
Address |
IOService.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Map<EndpointQualifier,Address> |
NodeIOService.getThisAddresses() |
Map<EndpointQualifier,Address> |
IOService.getThisAddresses() |
Modifier and Type | Method and Description |
---|---|
T |
EndpointManager.getConnection(Address address)
Gets the connection for a given address.
|
T |
EndpointManager.getOrConnect(Address address)
Gets the existing connection for a given address or connects.
|
T |
EndpointManager.getOrConnect(Address address,
boolean silent)
Gets the existing connection for a given address.
|
void |
NodeIOService.onDisconnect(Address endpoint,
Throwable cause) |
void |
IOService.onDisconnect(Address endpoint,
Throwable cause) |
void |
NodeIOService.onFailedConnection(Address address) |
void |
IOService.onFailedConnection(Address address) |
void |
NodeIOService.onSuccessfulConnection(Address address) |
void |
IOService.onSuccessfulConnection(Address address) |
boolean |
EndpointManager.registerConnection(Address address,
T connection)
Registers (ie.
|
void |
NodeIOService.removeEndpoint(Address endPoint) |
void |
IOService.removeEndpoint(Address endpoint) |
void |
NodeIOService.shouldConnectTo(Address address) |
void |
IOService.shouldConnectTo(Address address) |
boolean |
EndpointManager.transmit(Packet packet,
Address target)
Transmits a packet to a certain address.
|
Constructor and Description |
---|
Address(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
TcpIpConnectionErrorHandler.getEndPoint() |
Address |
TcpIpConnection.getEndPoint() |
Modifier and Type | Method and Description |
---|---|
TcpIpConnection |
TcpIpEndpointManager.getConnection(Address address) |
TcpIpConnection |
TcpIpEndpointManager.getOrConnect(Address address) |
TcpIpConnection |
TcpIpEndpointManager.getOrConnect(Address address,
boolean silent) |
boolean |
TcpIpEndpointManager.registerConnection(Address remoteEndPoint,
TcpIpConnection connection) |
void |
TcpIpConnection.setEndPoint(Address endPoint) |
boolean |
TcpIpEndpointManager.transmit(Packet packet,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
PartitionLostEvent.getEventSource()
Returns the address of the node that dispatches the event
|
Constructor and Description |
---|
PartitionLostEvent(int partitionId,
int lostBackupCount,
Address eventSource) |
Constructor and Description |
---|
ReplicatedMapCantBeCreatedOnLiteMemberException(Address address) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicatedMapEventPublishingService.fireEntryListenerEvent(Data key,
Data oldValue,
Data value,
EntryEventType eventType,
String name,
Address caller) |
void |
ReplicatedMapEventPublishingService.fireEntryListenerEvent(Data key,
Data oldValue,
Data value,
String name,
Address caller) |
Modifier and Type | Method and Description |
---|---|
protected Collection<Address> |
AbstractReplicatedMapOperation.getMemberAddresses() |
protected Collection<Address> |
ClearOperation.getMemberAddresses() |
Constructor and Description |
---|
ReplicateUpdateOperation(String name,
Data dataKey,
Data dataValue,
long ttl,
VersionResponsePair response,
boolean isRemove,
Address origin) |
Modifier and Type | Method and Description |
---|---|
abstract Address |
ScheduledTaskHandler.getAddress()
Returns the address of the member the task is associated with.
|
Modifier and Type | Method and Description |
---|---|
Address |
ScheduledTaskHandlerImpl.getAddress() |
Modifier and Type | Method and Description |
---|---|
static ScheduledTaskHandler |
ScheduledTaskHandlerImpl.of(Address addr,
String schedulerName,
String taskName) |
static void |
ScheduledTaskHandlerAccessor.setAddress(ScheduledTaskHandler handler,
Address newAddress) |
Modifier and Type | Field and Description |
---|---|
protected Address |
InvocationBuilder.target |
Modifier and Type | Method and Description |
---|---|
Address |
Operation.getCallerAddress() |
Address |
NodeEngine.getMasterAddress()
Gets the address of the master member.
|
Address |
EventRegistration.getSubscriber()
Returns the subscriber of this registration.
|
Address |
InvocationBuilder.getTarget()
Returns the target machine.
|
Address |
NodeEngine.getThisAddress()
Get the address of this member.
|
Modifier and Type | Method and Description |
---|---|
Set<Address> |
CallsPerMember.addresses() |
Modifier and Type | Method and Description |
---|---|
void |
LiveOperations.add(Address address,
long callId)
Registers an invocation with this object.
|
void |
CallsPerMember.add(Address address,
long callId) |
void |
CallsPerMember.addOpToCancel(Address address,
long callId) |
boolean |
CanCancelOperations.cancelOperation(Address caller,
long callId)
Notifies this service that an operation was requested to be cancelled.
|
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
void |
CallsPerMember.ensureMember(Address address)
Makes sure that a list of counters is created for a member.
|
com.hazelcast.spi.CallsPerMember.CategorizedCallIds |
CallsPerMember.getOrCreateCallIdsForMember(Address address) |
<E> InternalCompletableFuture<E> |
OperationService.invokeOnTarget(String serviceName,
Operation op,
Address target) |
boolean |
OperationService.send(Operation op,
Address target)
Executes an operation remotely.
|
static void |
OperationAccessor.setCallerAddress(Operation op,
Address caller) |
OperationControl |
CallsPerMember.toOpControl(Address address) |
Constructor and Description |
---|
CallsPerMember(Address localAddress) |
InvocationBuilder(String serviceName,
Operation op,
int partitionId,
Address target)
Creates an InvocationBuilder
|
Modifier and Type | Method and Description |
---|---|
Address |
SimpleDiscoveryNode.getPrivateAddress() |
abstract Address |
DiscoveryNode.getPrivateAddress()
Returns the private address of the discovered node.
|
Address |
SimpleDiscoveryNode.getPublicAddress() |
abstract Address |
DiscoveryNode.getPublicAddress()
Returns the public address of the discovered node if available.
|
Constructor and Description |
---|
SimpleDiscoveryNode(Address privateAddress)
This constructor will set private and public addresses to the same value and no properties
are available.
|
SimpleDiscoveryNode(Address privateAddress,
Address publicAddress)
This constructor will set private and public addresses separately and no properties are available.
|
SimpleDiscoveryNode(Address privateAddress,
Address publicAddress,
Map<String,Object> properties)
This constructor will set private and public addresses separately.
|
SimpleDiscoveryNode(Address privateAddress,
Map<String,Object> properties)
This constructor will set private and public addresses to the same value.
|
Constructor and Description |
---|
CallerNotMemberException(Address thisAddress,
Address caller,
int partitionId,
String operationName,
String serviceName) |
PartitionMigratingException(Address thisAddress,
int partitionId,
String operationName,
String serviceName) |
Modifier and Type | Method and Description |
---|---|
Address |
NodeEngineImpl.getMasterAddress() |
Address |
PortablePartitionLostEvent.getSource() |
Address |
NodeEngineImpl.getThisAddress() |
Constructor and Description |
---|
PortablePartitionLostEvent(int partitionId,
int lostBackupCount,
Address source) |
Modifier and Type | Method and Description |
---|---|
Address |
Registration.getSubscriber() |
Constructor and Description |
---|
Registration(String id,
String serviceName,
String topic,
EventFilter filter,
Address subscriber,
Object listener,
boolean localOnly) |
Constructor and Description |
---|
OperationExecutorImpl(HazelcastProperties properties,
LoggingService loggerService,
Address thisAddress,
OperationRunnerFactory runnerFactory,
NodeExtension nodeExtension,
String hzName,
ClassLoader configClassLoader) |
Modifier and Type | Method and Description |
---|---|
void |
InternalOperationService.onEndpointLeft(Address endpoint)
Cleans up heartbeats and fails invocations for the given endpoint.
|
void |
TargetAware.setTarget(Address address)
Provides the designated target member address to which the operation
will be sent.
|
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<Address,AtomicLong> |
InvocationMonitor.getHeartbeatPerMember() |
Modifier and Type | Method and Description |
---|---|
InvocationBuilder |
OperationServiceImpl.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
<E> InternalCompletableFuture<E> |
OperationServiceImpl.invokeOnTarget(String serviceName,
Operation op,
Address target) |
void |
OperationServiceImpl.onEndpointLeft(Address endpoint) |
boolean |
OutboundResponseHandler.send(EndpointManager endpointManager,
Address target,
Response response) |
boolean |
OperationServiceImpl.send(Operation op,
Address target) |
boolean |
OutboundOperationHandler.send(Operation op,
Address target) |
void |
OutboundResponseHandler.sendBackupAck(EndpointManager endpointManager,
Address target,
long callId,
boolean urgent) |
Constructor and Description |
---|
OutboundOperationHandler(Node node,
Address thisAddress,
InternalSerializationService serializationService) |
Constructor and Description |
---|
Backup(Data backupOpData,
Address originalCaller,
long[] replicaVersions,
boolean sync) |
Backup(Operation backupOp,
Address originalCaller,
long[] replicaVersions,
boolean sync) |
Modifier and Type | Method and Description |
---|---|
Address |
IPartitionLostEvent.getEventSource()
The address of the node that detects the partition lost.
|
Address |
IPartition.getOwnerOrNull()
Returns the address of the owner of this partition.
|
Address |
IPartitionService.getPartitionOwner(int partitionId)
Gets the owner of the partition if it's set.
|
Address |
IPartitionService.getPartitionOwnerOrWait(int partitionId)
Gets the owner of the partition.
|
Address |
IPartition.getReplicaAddress(int replicaIndex)
Returns the address of the replica.
|
Modifier and Type | Method and Description |
---|---|
Map<Address,List<Integer>> |
IPartitionService.getMemberPartitionsMap()
Gets member partition IDs.
|
Modifier and Type | Method and Description |
---|---|
List<Integer> |
IPartitionService.getMemberPartitions(Address target)
Returns partition ID list assigned to given target.
|
boolean |
IPartition.isOwnerOrBackup(Address address)
Checks if given address is owner of primary or backup of this partition.
|
Constructor and Description |
---|
IPartitionLostEvent(int partitionId,
int lostReplicaIndex,
Address eventSource) |
Modifier and Type | Method and Description |
---|---|
Address |
ReliableTopicMessage.getPublisherAddress() |
Constructor and Description |
---|
ReliableTopicMessage(Data payload,
Address publisherAddress) |
Modifier and Type | Method and Description |
---|---|
Address |
TargetAwareTransactionLogRecord.getTarget()
Returns target of changes made by this transaction record.
|
Modifier and Type | Method and Description |
---|---|
static String |
UuidUtil.createClientUuid(Address endpoint)
Creates a new client
UUID string,
based on a cryptographically weak pseudo random number generator. |
static String |
UuidUtil.createMemberUuid(Address endpoint)
Creates a new member
UUID string,
based on a cryptographically weak pseudo random number generator. |
Copyright © 2021 Hazelcast, Inc.. All Rights Reserved.