Package | Description |
---|---|
com.hazelcast.cache.impl.client |
Hazelcast JSR-107 aka JCache implementation
Client Requests
|
com.hazelcast.client |
Contains classes/interfaces related to Client
|
com.hazelcast.client.connection |
Provides connection interfaces/classes for com.hazelcast.client
|
com.hazelcast.client.connection.nio |
Contains classes related to New IO for com.hazelcast.client.connection
|
com.hazelcast.client.impl |
Contains most of the client side HazelcastInstance implementation functionality.
|
com.hazelcast.client.impl.client |
This contains the Requests and other DTO's exchanged between client/server
|
com.hazelcast.client.impl.protocol.codec |
Client protocol custom codec implementations
|
com.hazelcast.client.impl.protocol.task |
Client tasks associated with requests.
|
com.hazelcast.client.impl.protocol.task.map |
Client protocol tasks implementations for map
|
com.hazelcast.client.impl.protocol.task.transaction |
Client protocol tasks implementations for Transaction related
|
com.hazelcast.client.impl.protocol.template | |
com.hazelcast.client.spi |
Contains classes/interfaces related to Service Provider Interface
such as ClientProxy , ClientClusterService
|
com.hazelcast.client.spi.impl |
Provides util classes for com.hazelcast.client
|
com.hazelcast.client.spi.impl.discovery | |
com.hazelcast.client.spi.impl.listener | |
com.hazelcast.client.util |
This package contains some utility classes and the base implementations of the
loadbalancer implementations
|
com.hazelcast.cluster |
This package contains the cluster functionality.
|
com.hazelcast.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.cluster.impl.operations |
This package contains operations for the com.hazelcast.cluster.impl package.
|
com.hazelcast.collection.impl.collection | |
com.hazelcast.collection.impl.queue | |
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.executor.impl |
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the ExecutorService and provides all kinds
of additional methods related to distributed systems. |
com.hazelcast.executor.impl.client |
This package contains client requests for the IExecutorService.
|
com.hazelcast.instance |
This package contains Hazelcast Instance functionality.
|
com.hazelcast.internal.management |
Contains classes to provide data/operation interface for Management Center.
|
com.hazelcast.map.impl |
Contains implementation specific classes of
com.hazelcast.map package. |
com.hazelcast.map.impl.client |
Contains client requests for the
IMap |
com.hazelcast.map.impl.event | |
com.hazelcast.map.impl.querycache.event |
This package contains classes for query cache events.
|
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.nio |
This package contains classes related to New IO
|
com.hazelcast.nio.tcp |
Contains functionality for the TCP/IP Networking between cluster members
|
com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
com.hazelcast.partition.client |
Contains client functionality for partition related information.
|
com.hazelcast.partition.impl |
Contains the actual implementation of the
InternalPartitionService . |
com.hazelcast.replicatedmap |
Contains classes related to cluster quorum.
|
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.spi |
Provides interfaces/classes for Hazelcast SPI.
|
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.classic |
Contains the
ClassicOperationExecutor code. |
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.impl.waitnotifyservice.impl |
Contains the implementation code for the
InternalWaitNotifyService . |
com.hazelcast.topic.impl |
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. |
com.hazelcast.topic.impl.reliable | |
com.hazelcast.transaction.client |
This package contains client transaction code
|
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.
|
Constructor and Description |
---|
CacheListenerRegistrationRequest(String name,
javax.cache.configuration.CacheEntryListenerConfiguration cacheEntryListenerConfiguration,
boolean register,
Address target) |
CacheManagementConfigRequest(String name,
boolean isStat,
boolean enabled,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientEngine.getMasterAddress() |
Address |
ClientEngine.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Address |
AddressTranslator.translate(Address address)
Translates the given address to another address specific to
network or service
|
Modifier and Type | Method and Description |
---|---|
Connection |
ClientConnectionManager.getConnection(Address address) |
Connection |
ClientConnectionManager.getOrConnect(Address address,
Authenticator authenticator) |
Connection |
ClientConnectionManager.getOrTriggerConnect(Address address,
Authenticator authenticator) |
Address |
AddressTranslator.translate(Address address)
Translates the given address to another address specific to
network or service
|
Modifier and Type | Method and Description |
---|---|
Address |
ClientConnection.getEndPoint() |
Address |
ClientConnection.getRemoteEndpoint() |
Modifier and Type | Method and Description |
---|---|
protected ClientConnection |
ClientConnectionManagerImpl.createSocketConnection(Address address) |
ClientConnection |
ClientConnectionManagerImpl.getConnection(Address target) |
ClientConnection |
ClientConnectionManagerImpl.getOrConnect(Address target,
Authenticator authenticator) |
ClientConnection |
ClientConnectionManagerImpl.getOrTriggerConnect(Address target,
Authenticator authenticator) |
void |
ClientConnection.setRemoteEndpoint(Address remoteEndpoint) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientEngineImpl.getMasterAddress() |
Address |
ClientEngineImpl.getThisAddress() |
Constructor and Description |
---|
MemberImpl(Address address) |
MemberImpl(Address address,
String uuid) |
MemberImpl(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
Modifier and Type | Method and Description |
---|---|
abstract Collection<Address> |
MultiTargetClientRequest.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected InvocationBuilder |
InvocationClientRequest.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
Modifier and Type | Method and Description |
---|---|
protected abstract Object |
MultiTargetClientRequest.reduce(Map<Address,Object> map) |
Constructor and Description |
---|
ClientCreateRequest(String name,
String serviceName,
Address target) |
Modifier and Type | Method and Description |
---|---|
static Address |
AddressCodec.decode(ClientMessage clientMessage) |
Modifier and Type | Method and Description |
---|---|
static int |
AddressCodec.calculateDataSize(Address address) |
static void |
AddressCodec.encode(Address address,
ClientMessage clientMessage) |
Modifier and Type | Method and Description |
---|---|
abstract Collection<Address> |
AbstractMultiTargetMessageTask.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected ClientMessage |
AuthenticationMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte version) |
protected abstract ClientMessage |
AuthenticationBaseMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte serializationVersion) |
protected ClientMessage |
AuthenticationCustomCredentialsMessageTask.encodeAuth(byte status,
Address thisAddress,
String uuid,
String ownerUuid,
byte version) |
Modifier and Type | Method and Description |
---|---|
protected abstract Object |
AbstractMultiTargetMessageTask.reduce(Map<Address,Object> map) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
MapAddInterceptorMessageTask.getTargets() |
Collection<Address> |
MapRemoveInterceptorMessageTask.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected Object |
MapAddInterceptorMessageTask.reduce(Map<Address,Object> map) |
protected Object |
MapRemoveInterceptorMessageTask.reduce(Map<Address,Object> map) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
XACollectTransactionsMessageTask.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected Object |
XACollectTransactionsMessageTask.reduce(Map<Address,Object> map) |
Modifier and Type | Method and Description |
---|---|
Object |
ResponseTemplate.Authentication(byte status,
Address address,
String uuid,
String ownerUuid,
byte serializationVersion) |
Object |
ExecutorServiceCodecTemplate.cancelOnAddress(String uuid,
Address address,
boolean interrupt) |
void |
MapCodecTemplate.clearNearCache(String name,
Address target) |
void |
ClientMessageTemplate.createProxy(String name,
String serviceName,
Address target) |
void |
CacheCodecTemplate.listenerRegistration(String name,
Data listenerConfig,
boolean shouldRegister,
Address address) |
void |
CacheCodecTemplate.managementConfig(String name,
boolean isStat,
boolean enabled,
Address address) |
void |
EventResponseTemplate.PartitionLost(int partitionId,
int lostBackupCount,
Address source) |
Object |
ExecutorServiceCodecTemplate.submitToAddress(String name,
String uuid,
Data callable,
Address address) |
Modifier and Type | Method and Description |
---|---|
void |
ResponseTemplate.Partitions(Map<Address,List<Integer>> partitions) |
Modifier and Type | Method and Description |
---|---|
Address |
ProxyManager.findNextAddressToSendCreateRequest() |
Address |
ClientClusterService.getMasterAddress()
Returns the address of the master member.
|
Address |
ClientClusterService.getOwnerConnectionAddress()
The owner connection is opened to owner member of the client in the cluster.
|
Address |
ClientPartitionService.getPartitionOwner(int partitionId) |
Modifier and Type | Method and Description |
---|---|
Member |
ClientClusterService.getMember(Address address)
Gets the member for the given address.
|
void |
ClientInvocationService.invokeOnTarget(ClientInvocation invocation,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientClusterServiceImpl.getMasterAddress() |
Address |
ClusterListenerSupport.getOwnerConnectionAddress() |
Address |
ClientPartitionServiceImpl.getPartitionOwner(int partitionId) |
Address |
AwsAddressTranslator.translate(Address address) |
Address |
DefaultAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
Member |
ClientClusterServiceImpl.getMember(Address address) |
void |
ClientSmartInvocationServiceImpl.invokeOnTarget(ClientInvocation invocation,
Address target) |
void |
ClientNonSmartInvocationServiceImpl.invokeOnTarget(ClientInvocation invocation,
Address target) |
Address |
AwsAddressTranslator.translate(Address address) |
Address |
DefaultAddressTranslator.translate(Address address) |
Constructor and Description |
---|
ClientInvocation(HazelcastClientInstanceImpl client,
ClientMessage clientMessage,
Address address) |
ClientInvocation(HazelcastClientInstanceImpl client,
ClientMessage clientMessage,
int partitionId,
Address address,
Connection connection) |
Modifier and Type | Method and Description |
---|---|
Address |
DiscoveryAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
DiscoveryAddressTranslator.translate(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientEventRegistration.getSubscriber()
This is used when removing the listener.
|
Constructor and Description |
---|
ClientEventRegistration(String serverRegistrationId,
long callId,
Address subscriber,
ListenerMessageCodec codec) |
Constructor and Description |
---|
ClientAddressCancellableDelegatingFuture(ClientInvocationFuture future,
ClientContext context,
String uuid,
Address target,
V defaultValue,
ClientMessageDecoder resultDecoder) |
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 |
---|---|
void |
Joiner.blacklist(Address address,
boolean permanent)
Adds an address to the blacklist.
|
MemberImpl |
ClusterService.getMember(Address address)
Gets the member for the given address.
|
boolean |
Joiner.isBlacklisted(Address address)
Checks if an address is blacklisted.
|
void |
Joiner.setTargetAddress(Address targetAddress) |
boolean |
Joiner.unblacklist(Address address)
Removes an address from the blacklist if it's temporarily blacklisted.
|
Constructor and Description |
---|
MemberInfo(Address address) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
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 |
ClusterStateTransactionLogRecord.getTarget() |
Address |
AbstractJoiner.getTargetAddress() |
Address |
BindMessage.getTargetAddress() |
Address |
ClusterServiceImpl.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
ClusterServiceImpl.getMemberAddresses() |
Collection<Address> |
JoinMessage.getMemberAddresses() |
protected Collection<Address> |
DiscoveryJoiner.getPossibleAddresses() |
protected Collection<Address> |
TcpIpJoiner.getPossibleAddresses() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractJoiner.blacklist(Address address,
boolean permanent) |
void |
ClusterStateManager.commitClusterState(ClusterState newState,
Address initiator,
String txnId) |
static MulticastService |
MulticastService.createMulticastService(Address bindAddress,
Node node,
Config config,
ILogger logger) |
MemberImpl |
ClusterServiceImpl.getMember(Address address) |
void |
ClusterJoinManager.handleMaster(Address masterAddress,
Address callerAddress) |
boolean |
AbstractJoiner.isBlacklisted(Address address) |
boolean |
ClusterServiceImpl.isMemberRemovedWhileClusterIsNotActive(Address target) |
void |
ClusterStateManager.lockClusterState(ClusterState newState,
Address initiator,
String txnId,
long leaseTime,
int partitionStateVersion) |
void |
ClusterServiceImpl.merge(Address newTargetAddress) |
void |
ClusterServiceImpl.removeAddress(Address deadAddress) |
boolean |
ClusterJoinManager.sendJoinRequest(Address toAddress,
boolean withCredentials) |
boolean |
ClusterJoinManager.sendMasterQuestion(Address toAddress) |
void |
ClusterServiceImpl.sendMemberListToMember(Address target) |
void |
AbstractJoiner.setTargetAddress(Address targetAddress) |
protected void |
AbstractJoiner.startClusterMerge(Address targetAddress) |
boolean |
AbstractJoiner.unblacklist(Address address) |
Constructor and Description |
---|
BindMessage(Address localAddress,
Address targetAddress,
boolean reply) |
ClusterStateTransactionLogRecord(ClusterState newState,
Address initiator,
Address target,
String txnId,
long leaseTime,
int partitionStateVersion) |
JoinMessage(byte packetVersion,
int buildNumber,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck) |
JoinMessage(byte packetVersion,
int buildNumber,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount) |
JoinRequest(byte packetVersion,
int buildNumber,
Address address,
String uuid,
boolean liteMember,
ConfigCheck config,
Credentials credentials,
Map<String,Object> attributes) |
Constructor and Description |
---|
JoinMessage(byte packetVersion,
int buildNumber,
Address address,
String uuid,
boolean liteMember,
ConfigCheck configCheck,
Collection<Address> memberAddresses,
int dataMemberCount) |
Modifier and Type | Field and Description |
---|---|
protected Address |
SetMasterOperation.masterAddress |
Modifier and Type | Method and Description |
---|---|
Address |
SetMasterOperation.getMasterAddress() |
Constructor and Description |
---|
ChangeClusterStateOperation(ClusterState newState,
Address initiator,
String txnId) |
LockClusterStateOperation(ClusterState newState,
Address initiator,
String txnId,
long leaseTime,
int partitionStateVersion) |
MemberRemoveOperation(Address deadAddress) |
MergeClustersOperation(Address newTargetAddress) |
RollbackClusterStateOperation(Address initiator,
String txnId) |
SetMasterOperation(Address originAddress) |
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 |
---|---|
boolean |
DistributedExecutorService.isOperationExecuting(Address callerAddress,
String callerUuid,
Object identifier) |
Modifier and Type | Method and Description |
---|---|
Address |
SpecificTargetCallableRequest.getTarget() |
Constructor and Description |
---|
CancellationRequest(String uuid,
Address target,
boolean interrupt) |
SpecificTargetCallableRequest(String name,
String uuid,
Callable callable,
Address target) |
Modifier and Type | Field and Description |
---|---|
Address |
Node.address |
protected Address |
AbstractMember.address |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractMember.getAddress() |
Address |
AddressPicker.getBindAddress()
Returns a server socket listener address.
|
Address |
Node.getMasterAddress() |
Address |
AddressPicker.getPublicAddress()
Returns a public address to be advertised to other cluster members and clients.
|
Address |
Node.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
void |
Node.setMasterAddress(Address master) |
Constructor and Description |
---|
AbstractMember(Address address) |
AbstractMember(Address address,
String uuid) |
AbstractMember(Address address,
String uuid,
Map<String,Object> attributes) |
AbstractMember(Address address,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
MemberImpl(Address address,
boolean localMember) |
MemberImpl(Address address,
boolean localMember,
boolean liteMember) |
MemberImpl(Address address,
boolean localMember,
String uuid,
HazelcastInstanceImpl instance) |
MemberImpl(Address address,
boolean localMember,
String uuid,
HazelcastInstanceImpl instance,
Map<String,Object> attributes,
boolean liteMember) |
Modifier and Type | Method and Description |
---|---|
Object |
ManagementCenterService.callOnAddress(Address address,
Operation operation) |
void |
ManagementCenterService.send(Address address,
Operation operation) |
Modifier and Type | Method and Description |
---|---|
protected Address |
LocalMapStatsProvider.getReplicaAddress(int replica,
InternalPartition partition,
InternalPartitionService partitionService,
int backupCount)
Gets replica address.
|
protected Address |
LocalMapStatsProvider.waitForReplicaAddress(int replica,
InternalPartition partition,
InternalPartitionService partitionService,
int backupCount)
Waits partition table update to get replica address if current replica address is null.
|
Modifier and Type | Method and Description |
---|---|
protected void |
LocalMapStatsProvider.addReplicaPartitionStats(LocalMapStatsProvider.LocalMapOnDemandCalculatedStats onDemandStats,
String mapName,
int partitionId,
InternalPartition partition,
InternalPartitionService partitionService,
int backupCount,
Address thisAddress)
Calculates and adds replica partition stats.
|
protected boolean |
LocalMapStatsProvider.isReplicaAvailable(Address replicaAddress,
InternalPartitionService partitionService,
int backupCount) |
protected boolean |
LocalMapStatsProvider.isReplicaOnThisNode(Address replicaAddress,
Address thisAddress) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
MapAddInterceptorRequest.getTargets() |
Collection<Address> |
MapRemoveInterceptorRequest.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected Object |
MapAddInterceptorRequest.reduce(Map<Address,Object> map) |
protected Object |
MapRemoveInterceptorRequest.reduce(Map<Address,Object> map) |
Constructor and Description |
---|
MapClearNearCacheRequest(String name,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
EventData.getCaller() |
Modifier and Type | Method and Description |
---|---|
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 dataOldValue,
Object dataValue) |
void |
MapEventPublisher.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Object dataOldValue,
Object dataValue) |
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 dataOldValue,
Object dataValue,
Object dataMergingValue) |
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 |
---|---|
Address |
DefaultQueryCacheEventData.getCaller() |
Modifier and Type | Method and Description |
---|---|
Address |
JobPartitionState.getOwner()
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 |
---|---|
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 |
---|---|
Connection |
ConnectionManager.getConnection(Address address)
Gets the connection for a given address.
|
Connection |
ConnectionManager.getOrConnect(Address address)
Gets the existing connection for a given address or connects.
|
Connection |
ConnectionManager.getOrConnect(Address address,
boolean silent)
Gets the existing connection for a given address.
|
void |
NodeIOService.onDisconnect(Address endpoint) |
void |
IOService.onDisconnect(Address endpoint) |
void |
NodeIOService.onFailedConnection(Address address) |
void |
IOService.onFailedConnection(Address address) |
void |
NodeIOService.onSuccessfulConnection(Address address) |
void |
IOService.onSuccessfulConnection(Address address) |
boolean |
ConnectionManager.registerConnection(Address address,
Connection connection) |
void |
NodeIOService.removeEndpoint(Address endPoint) |
void |
IOService.removeEndpoint(Address endpoint) |
void |
NodeIOService.shouldConnectTo(Address address) |
void |
IOService.shouldConnectTo(Address address) |
boolean |
ConnectionManager.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 |
TcpIpConnectionMonitor.getEndPoint() |
Address |
TcpIpConnection.getEndPoint() |
Modifier and Type | Method and Description |
---|---|
Connection |
TcpIpConnectionManager.getConnection(Address address) |
Connection |
TcpIpConnectionManager.getOrConnect(Address address) |
Connection |
TcpIpConnectionManager.getOrConnect(Address address,
boolean silent) |
boolean |
TcpIpConnectionManager.registerConnection(Address remoteEndPoint,
Connection connection) |
void |
TcpIpConnection.setEndPoint(Address endPoint) |
boolean |
TcpIpConnectionManager.transmit(Packet packet,
Address target)
Retries sending packet maximum 5 times until connection to target becomes available.
|
Constructor and Description |
---|
InitConnectionTask(TcpIpConnectionManager connectionManager,
Address address,
boolean silent) |
TcpIpConnectionMonitor(TcpIpConnectionManager connectionManager,
Address endPoint) |
Modifier and Type | Method and Description |
---|---|
Address |
MigrationInfo.getDestination() |
Address |
PartitionRuntimeState.getEndpoint() |
Address |
InternalPartitionLostEvent.getEventSource()
The address of the node that detects the partition lost
|
Address |
PartitionLostEvent.getEventSource()
Returns the address of the node that dispatches the event
|
Address |
MigrationInfo.getMaster() |
Address |
InternalPartition.getOwnerOrNull()
Returns the Address of the owner of this partition.
|
Address |
InternalPartitionService.getPartitionOwner(int partitionId)
Gets the owner of the partition if it's set.
|
Address |
InternalPartitionService.getPartitionOwnerOrWait(int partitionId)
Gets the owner of the partition.
|
Address |
InternalPartition.getReplicaAddress(int replicaIndex)
Returns Address of the replica.
|
Address |
PartitionInfo.getReplicaAddress(int index) |
Address[] |
PartitionInfo.getReplicaAddresses() |
Address |
MigrationInfo.getSource() |
Modifier and Type | Method and Description |
---|---|
Map<Address,List<Integer>> |
InternalPartitionService.getMemberPartitionsMap()
Gets member partition IDs.
|
Modifier and Type | Method and Description |
---|---|
Member |
InternalPartitionService.getMember(Address address) |
List<Integer> |
InternalPartitionService.getMemberPartitions(Address target) |
boolean |
InternalPartition.isOwnerOrBackup(Address address)
Checks if given address is owner of primary or backup of this partition.
|
void |
PartitionRuntimeState.setEndpoint(Address endpoint) |
void |
MigrationInfo.setMaster(Address master) |
Constructor and Description |
---|
InternalPartitionLostEvent(int partitionId,
int lostReplicaIndex,
Address eventSource) |
MigrationInfo(int partitionId,
Address source,
Address destination) |
PartitionInfo(int partitionId,
Address[] addresses) |
PartitionLostEvent(int partitionId,
int lostBackupCount,
Address eventSource) |
Modifier and Type | Method and Description |
---|---|
Address[] |
PartitionsResponse.getMembers() |
Constructor and Description |
---|
PartitionsResponse(Address[] members,
int[] ownerIndexes) |
Modifier and Type | Method and Description |
---|---|
Address |
PartitionReplicaChangeEvent.getNewAddress() |
Address |
PartitionReplicaChangeEvent.getOldAddress() |
Address |
InternalPartitionServiceImpl.getPartitionOwner(int partitionId) |
Address |
InternalPartitionServiceImpl.getPartitionOwnerOrWait(int partitionId) |
Address[][] |
PartitionStateGenerator.initialize(Collection<MemberGroup> groups,
int partitionCount)
Returns the initial layout for the partitions.
|
Address[][] |
PartitionStateGeneratorImpl.initialize(Collection<MemberGroup> memberGroups,
int partitionCount) |
Address[][] |
PartitionStateGenerator.reArrange(Collection<MemberGroup> groups,
InternalPartition[] currentState)
Rearranges the partition layout.
|
Address[][] |
PartitionStateGeneratorImpl.reArrange(Collection<MemberGroup> memberGroups,
InternalPartition[] currentState) |
Modifier and Type | Method and Description |
---|---|
Map<Address,List<Integer>> |
InternalPartitionServiceImpl.getMemberPartitionsMap() |
Modifier and Type | Method and Description |
---|---|
void |
InternalPartitionServiceImpl.cancelReplicaSyncRequestsTo(Address deadAddress) |
MemberImpl |
InternalPartitionServiceImpl.getMember(Address address) |
List<Integer> |
InternalPartitionServiceImpl.getMemberPartitions(Address target) |
void |
InternalPartitionServiceImpl.setInitialState(Address[][] newState,
int partitionStateVersion) |
Constructor and Description |
---|
PartitionReplicaChangeEvent(int partitionId,
int replicaIndex,
Address oldAddress,
Address newAddress,
com.hazelcast.partition.impl.PartitionReplicaChangeReason reason) |
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 | 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 |
---|---|
InvocationBuilder |
OperationService.createInvocationBuilder(String serviceName,
Operation op,
Address target) |
<E> InternalCompletableFuture<E> |
OperationService.invokeOnTarget(String serviceName,
Operation op,
Address target) |
boolean |
ExecutionTracingService.isOperationExecuting(Address callerAddress,
String callerUuid,
Object identifier) |
boolean |
OperationService.send(Operation op,
Address target)
Executes an operation remotely.
|
boolean |
OperationService.send(Response response,
Address target)
Deprecated.
|
static void |
OperationAccessor.setCallerAddress(Operation op,
Address caller) |
Constructor and Description |
---|
InvocationBuilder(NodeEngineImpl nodeEngine,
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.
|
Modifier and Type | Method and Description |
---|---|
Address |
WrongTargetException.getTarget() |
Constructor and Description |
---|
CallerNotMemberException(Address thisAddress,
Address caller,
int partitionId,
String operationName,
String serviceName) |
PartitionMigratingException(Address thisAddress,
int partitionId,
String operationName,
String serviceName) |
TargetDisconnectedException(Address address) |
TargetNotMemberException(Address target,
int partitionId,
String operationName,
String serviceName) |
WrongTargetException(Address thisAddress,
Address target,
int partitionId,
int replicaIndex,
String operationName) |
WrongTargetException(Address thisAddress,
Address target,
int partitionId,
int replicaIndex,
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 |
---|
ClassicOperationExecutor(GroupProperties properties,
LoggingService loggerService,
Address thisAddress,
OperationRunnerFactory operationRunnerFactory,
HazelcastThreadGroup hazelcastThreadGroup,
NodeExtension nodeExtension,
MetricsRegistry metricsRegistry) |
Modifier and Type | Method and Description |
---|---|
Address |
TargetInvocation.getTarget() |
Address |
PartitionInvocation.getTarget() |
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) |
boolean |
IsStillRunningService.isOperationExecuting(Address callerAddress,
int partitionId,
long operationCallId)
Checks if an operation is still running.
|
boolean |
IsStillRunningService.isOperationExecuting(Address callerAddress,
String callerUuid,
String serviceName,
Object identifier)
Checks if an operation is still running.
|
void |
InvocationRegistry.notify(Response response,
Address sender)
Notifies the invocation that a Response is available.
|
boolean |
OperationServiceImpl.send(Operation op,
Address target) |
boolean |
OperationServiceImpl.send(Response response,
Address target) |
Constructor and Description |
---|
InvocationBuilderImpl(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target) |
TargetInvocation(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target,
int tryCount,
long tryPauseMillis,
long callTimeout,
ExecutionCallback callback,
boolean resultDeserialized) |
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 |
---|---|
void |
WaitNotifyServiceImpl.onPartitionMigrate(Address thisAddress,
MigrationInfo migrationInfo) |
Modifier and Type | Field and Description |
---|---|
Address |
TopicEvent.publisherAddress |
Constructor and Description |
---|
TopicEvent(String name,
Data data,
Address publisherAddress) |
Modifier and Type | Method and Description |
---|---|
Address |
ReliableTopicMessage.getPublisherAddress() |
Constructor and Description |
---|
ReliableTopicMessage(Data payload,
Address publisherAddress) |
Modifier and Type | Method and Description |
---|---|
Collection<Address> |
CollectXATransactionsRequest.getTargets() |
Modifier and Type | Method and Description |
---|---|
protected Object |
CollectXATransactionsRequest.reduce(Map<Address,Object> map) |
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 © 2016 Hazelcast, Inc.. All Rights Reserved.