Uses of Class
com.hazelcast.nio.Address

Packages that use Address
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.parameters Client protocol parameter implementations for client requests and responses 
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.util Protocol utils 
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.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.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.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.impl.record This package contains the implementation of the backing data storage for the replicated map implementation 
com.hazelcast.spi Provides interfaces/classes for Hazelcast SPI. 
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 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.impl.transceiver Contains the code for the PacketTransceiver
com.hazelcast.spi.impl.transceiver.impl Contains the implementation of the PacketTransceiver
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.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.wan.impl This package contains the opensource implementation of WAN replication 
 

Uses of Address in com.hazelcast.cache.impl.client
 

Constructors in com.hazelcast.cache.impl.client with parameters of type Address
CacheListenerRegistrationRequest(String name, javax.cache.configuration.CacheEntryListenerConfiguration cacheEntryListenerConfiguration, boolean register, Address target)
           
CacheManagementConfigRequest(String name, boolean isStat, boolean enabled, Address target)
           
 

Uses of Address in com.hazelcast.client
 

Methods in com.hazelcast.client that return Address
 Address ClientEngine.getMasterAddress()
           
 Address ClientEngine.getThisAddress()
           
 

Uses of Address in com.hazelcast.client.connection
 

Methods in com.hazelcast.client.connection that return Address
 Address Router.next()
           
 Address AddressTranslator.translate(Address address)
          Translates the given address to another address specific to network or service
 

Methods in com.hazelcast.client.connection with parameters of type Address
 Connection ClientConnectionManager.getConnection(Address address)
           
 Connection ClientConnectionManager.getOrConnect(Address address, Authenticator authenticator)
           
 Address AddressTranslator.translate(Address address)
          Translates the given address to another address specific to network or service
 

Uses of Address in com.hazelcast.client.connection.nio
 

Methods in com.hazelcast.client.connection.nio that return Address
 Address ClientConnection.getEndPoint()
           
 Address ClientConnection.getRemoteEndpoint()
           
 

Methods in com.hazelcast.client.connection.nio with parameters of type Address
 ClientConnection ClientConnectionManagerImpl.getConnection(Address target)
           
 ClientConnection ClientConnectionManagerImpl.getOrConnect(Address target, Authenticator authenticator)
           
 void ClientConnection.setRemoteEndpoint(Address remoteEndpoint)
           
 

Uses of Address in com.hazelcast.client.impl
 

Methods in com.hazelcast.client.impl that return Address
 Address ClientEngineImpl.getMasterAddress()
           
 Address ClientEngineImpl.getThisAddress()
           
 

Constructors in com.hazelcast.client.impl with parameters of type Address
MemberImpl(Address address)
           
MemberImpl(Address address, String uuid)
           
MemberImpl(Address address, String uuid, Map<String,Object> attributes)
           
 

Uses of Address in com.hazelcast.client.impl.client
 

Methods in com.hazelcast.client.impl.client that return types with arguments of type Address
abstract  Collection<Address> MultiTargetClientRequest.getTargets()
           
 

Methods in com.hazelcast.client.impl.client with parameters of type Address
protected  InvocationBuilder InvocationClientRequest.createInvocationBuilder(String serviceName, Operation op, Address target)
           
 

Method parameters in com.hazelcast.client.impl.client with type arguments of type Address
protected abstract  Object MultiTargetClientRequest.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.client.impl.protocol.parameters
 

Fields in com.hazelcast.client.impl.protocol.parameters declared as Address
 Address AuthenticationResultParameters.address
           
 Address[] GetPartitionsResultParameters.members
           
 Address PartitionLostEventParameters.source
           
 

Methods in com.hazelcast.client.impl.protocol.parameters that return Address
static Address AddressCodec.decode(ClientMessage clientMessage)
           
 

Methods in com.hazelcast.client.impl.protocol.parameters with parameters of type Address
static int AddressCodec.calculateDataSize(Address address)
           
static int GetPartitionsResultParameters.calculateDataSize(Address[] addresses, int[] ownerIndexes)
          sample data size estimation
static int AuthenticationResultParameters.calculateDataSize(Address address, String uuid, String ownerUuid)
          sample data size estimation
static int PartitionLostEventParameters.calculateDataSize(int partitionId, int lostBackupCount, Address source)
          sample data size estimation
static ClientMessage GetPartitionsResultParameters.encode(Address[] addresses, int[] ownerIndexes)
           
static void AddressCodec.encode(Address address, ClientMessage clientMessage)
           
static ClientMessage AuthenticationResultParameters.encode(Address address, String uuid, String ownerUuid)
           
static ClientMessage PartitionLostEventParameters.encode(int partitionId, int lostBackupCount, Address source)
           
 

Uses of Address in com.hazelcast.client.impl.protocol.task
 

Methods in com.hazelcast.client.impl.protocol.task that return types with arguments of type Address
abstract  Collection<Address> AbstractMultiTargetMessageTask.getTargets()
           
 

Method parameters in com.hazelcast.client.impl.protocol.task with type arguments of type Address
protected abstract  ClientMessage AbstractMultiTargetMessageTask.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.client.impl.protocol.task.map
 

Methods in com.hazelcast.client.impl.protocol.task.map that return types with arguments of type Address
 Collection<Address> MapAddInterceptorMessageTask.getTargets()
           
 Collection<Address> MapRemoveInterceptorMessageTask.getTargets()
           
 

Method parameters in com.hazelcast.client.impl.protocol.task.map with type arguments of type Address
protected  ClientMessage MapAddInterceptorMessageTask.reduce(Map<Address,Object> map)
           
protected  ClientMessage MapRemoveInterceptorMessageTask.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.client.impl.protocol.task.transaction
 

Methods in com.hazelcast.client.impl.protocol.task.transaction that return types with arguments of type Address
 Collection<Address> XACollectTransactionsMessageTask.getTargets()
           
 

Method parameters in com.hazelcast.client.impl.protocol.task.transaction with type arguments of type Address
protected  ClientMessage XACollectTransactionsMessageTask.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.client.impl.protocol.util
 

Methods in com.hazelcast.client.impl.protocol.util that return Address
static Address ParameterUtil.decodeAddress(ClientMessage clientMessage)
           
 

Methods in com.hazelcast.client.impl.protocol.util with parameters of type Address
static int ParameterUtil.calculateAddressDataSize(Address address)
           
static void ParameterUtil.encodeAddress(ClientMessage clientMessage, Address address)
           
 

Uses of Address in com.hazelcast.client.spi
 

Methods in com.hazelcast.client.spi that return Address
 Address ClientClusterService.getMasterAddress()
          Returns the address of the master member.
 Address ClientClusterService.getOwnerConnectionAddress()
          Owner connection is opened to owner member of the client in the cluster.
 Address ClientPartitionService.getPartitionOwner(int partitionId)
           
 

Methods in com.hazelcast.client.spi with parameters of type Address
 MemberImpl ClientClusterService.getMember(Address address)
          Gets the member for the given address.
protected
<T> T
ClientProxy.invoke(ClientRequest req, Address address)
           
 void ClientInvocationService.invokeOnTarget(ClientInvocation invocation, Address target)
           
<T> ICompletableFuture<T>
ClientInvocationService.invokeOnTarget(ClientRequest request, Address target)
           
 

Uses of Address in com.hazelcast.client.spi.impl
 

Methods in com.hazelcast.client.spi.impl that return Address
 Address ClientClusterServiceImpl.getMasterAddress()
           
 Address ClusterListenerSupport.getOwnerConnectionAddress()
           
 Address ClientPartitionServiceImpl.getPartitionOwner(int partitionId)
           
 Address AwsAddressTranslator.translate(Address address)
           
 Address DefaultAddressTranslator.translate(Address address)
           
 

Methods in com.hazelcast.client.spi.impl with parameters of type Address
 MemberImpl 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)
           
 

Constructors in com.hazelcast.client.spi.impl with parameters of type Address
ClientInvocation(HazelcastClientInstanceImpl client, ClientRequest request, Address address)
           
ClientInvocation(HazelcastClientInstanceImpl client, EventHandler handler, ClientRequest request, Address address)
           
 

Uses of Address in com.hazelcast.client.util
 

Constructors in com.hazelcast.client.util with parameters of type Address
ClientCancellableDelegatingFuture(ICompletableFuture future, ClientContext context, String uuid, Address target, int partitionId, V defaultValue)
           
 

Uses of Address in com.hazelcast.cluster
 

Methods in com.hazelcast.cluster that return Address
 Address MemberInfo.getAddress()
           
 Address ClusterService.getMasterAddress()
          Returns the address of the master member.
 Address ClusterService.getThisAddress()
          Gets the address of this member.
 

Methods in com.hazelcast.cluster with parameters of type Address
 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.
 

Constructors in com.hazelcast.cluster with parameters of type Address
MemberInfo(Address address)
           
MemberInfo(Address address, String uuid, Map<String,Object> attributes)
           
 

Uses of Address in com.hazelcast.cluster.impl
 

Fields in com.hazelcast.cluster.impl declared as Address
protected  Address JoinMessage.address
           
protected  Address ClusterServiceImpl.thisAddress
           
 

Fields in com.hazelcast.cluster.impl with type parameters of type Address
protected  ConcurrentMap<Address,Boolean> AbstractJoiner.blacklistedAddresses
           
 

Methods in com.hazelcast.cluster.impl that return Address
 Address JoinMessage.getAddress()
           
 Address BindMessage.getLocalAddress()
           
 Address ClusterServiceImpl.getMasterAddress()
           
 Address AbstractJoiner.getTargetAddress()
           
 Address BindMessage.getTargetAddress()
           
 Address ClusterServiceImpl.getThisAddress()
           
 

Methods in com.hazelcast.cluster.impl with parameters of type Address
 void AbstractJoiner.blacklist(Address address, boolean permanent)
           
 JoinRequest ClusterServiceImpl.checkJoinInfo(Address target)
           
protected  MemberImpl ClusterServiceImpl.createMember(Address address, String nodeUuid, String ipV6ScopeId, Map<String,Object> attributes)
           
 MemberImpl ClusterServiceImpl.getMember(Address address)
           
 void ClusterServiceImpl.handleMaster(Address masterAddress, Address callerAddress)
           
 boolean AbstractJoiner.isBlacklisted(Address address)
           
 void ClusterServiceImpl.merge(Address newTargetAddress)
           
 void ClusterServiceImpl.prepareToMerge(Address newTargetAddress)
           
 void ClusterServiceImpl.removeAddress(Address deadAddress)
           
 boolean ClusterServiceImpl.sendJoinRequest(Address toAddress, boolean withCredentials)
           
 boolean ClusterServiceImpl.sendMasterQuestion(Address toAddress)
           
 void AbstractJoiner.setTargetAddress(Address targetAddress)
           
protected  void AbstractJoiner.startClusterMerge(Address targetAddress)
           
 boolean AbstractJoiner.unblacklist(Address address)
           
 

Constructors in com.hazelcast.cluster.impl with parameters of type Address
BindMessage(Address localAddress, Address targetAddress, boolean reply)
           
JoinMessage(byte packetVersion, int buildNumber, Address address, String uuid, ConfigCheck configCheck, int memberCount)
           
JoinRequest(byte packetVersion, int buildNumber, Address address, String uuid, ConfigCheck config, Credentials credentials, int memberCount, int tryCount, Map<String,Object> attributes)
           
 

Uses of Address in com.hazelcast.cluster.impl.operations
 

Fields in com.hazelcast.cluster.impl.operations declared as Address
protected  Address SetMasterOperation.masterAddress
           
 

Methods in com.hazelcast.cluster.impl.operations that return Address
 Address SetMasterOperation.getMasterAddress()
           
 

Constructors in com.hazelcast.cluster.impl.operations with parameters of type Address
MemberRemoveOperation(Address deadAddress)
           
MergeClustersOperation(Address newTargetAddress)
           
PrepareMergeOperation(Address newTargetAddress)
           
SetMasterOperation(Address originAddress)
           
 

Uses of Address in com.hazelcast.collection.impl.collection
 

Methods in com.hazelcast.collection.impl.collection that return Address
 Address CollectionEvent.getCaller()
           
 

Constructors in com.hazelcast.collection.impl.collection with parameters of type Address
CollectionEvent(String name, Data data, ItemEventType eventType, Address caller)
           
 

Uses of Address in com.hazelcast.collection.impl.queue
 

Constructors in com.hazelcast.collection.impl.queue with parameters of type Address
QueueEvent(String name, Data data, ItemEventType eventType, Address caller)
           
 

Uses of Address in com.hazelcast.executor.impl
 

Methods in com.hazelcast.executor.impl with parameters of type Address
 boolean DistributedExecutorService.isOperationExecuting(Address callerAddress, String callerUuid, Object identifier)
           
 

Uses of Address in com.hazelcast.executor.impl.client
 

Methods in com.hazelcast.executor.impl.client that return Address
 Address SpecificTargetCallableRequest.getTarget()
           
 

Constructors in com.hazelcast.executor.impl.client with parameters of type Address
CancellationRequest(String uuid, Address target, boolean interrupt)
           
SpecificTargetCallableRequest(String name, String uuid, Callable callable, Address target)
           
 

Uses of Address in com.hazelcast.instance
 

Fields in com.hazelcast.instance declared as Address
 Address Node.address
           
protected  Address AbstractMember.address
           
 

Methods in com.hazelcast.instance that return Address
 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()
           
 

Methods in com.hazelcast.instance with parameters of type Address
 void Node.setMasterAddress(Address master)
           
 

Constructors in com.hazelcast.instance with parameters of type Address
AbstractMember(Address address)
           
AbstractMember(Address address, String uuid)
           
AbstractMember(Address address, String uuid, Map<String,Object> attributes)
           
MemberImpl(Address address, boolean localMember)
           
MemberImpl(Address address, boolean localMember, String uuid, HazelcastInstanceImpl instance)
           
MemberImpl(Address address, boolean localMember, String uuid, HazelcastInstanceImpl instance, Map<String,Object> attributes)
           
 

Uses of Address in com.hazelcast.internal.management
 

Methods in com.hazelcast.internal.management with parameters of type Address
 Object ManagementCenterService.callOnAddress(Address address, Operation operation)
           
 void ManagementCenterService.send(Address address, Operation operation)
           
 

Uses of Address in com.hazelcast.map.impl
 

Methods in com.hazelcast.map.impl that return Address
 Address EventData.getCaller()
           
 

Methods in com.hazelcast.map.impl with parameters of type Address
 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 MapEventPublisher.publishEvent(Address caller, String mapName, EntryEventType eventType, boolean synthetic, Data dataKey, Data dataOldValue, Data dataValue)
           
 void MapEventPublisher.publishEvent(Address caller, String mapName, EntryEventType eventType, boolean synthetic, Data dataKey, Data dataOldValue, Data dataValue, Data dataMergingValue)
           
 void MapEventPublisher.publishEvent(Address caller, String mapName, EntryEventType eventType, Data dataKey, Data dataOldValue, Data dataValue)
           
 void MapEventPublisher.publishMapEvent(Address caller, String mapName, EntryEventType eventType, int numberOfEntriesAffected)
           
 void MapEventPublisher.publishMapPartitionLostEvent(Address caller, String mapName, int partitionId)
           
 

Constructors in com.hazelcast.map.impl with parameters of type Address
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)
           
 

Uses of Address in com.hazelcast.map.impl.client
 

Methods in com.hazelcast.map.impl.client that return types with arguments of type Address
 Collection<Address> MapAddInterceptorRequest.getTargets()
           
 Collection<Address> MapRemoveInterceptorRequest.getTargets()
           
 

Method parameters in com.hazelcast.map.impl.client with type arguments of type Address
protected  Object MapAddInterceptorRequest.reduce(Map<Address,Object> map)
           
protected  Object MapRemoveInterceptorRequest.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.mapreduce
 

Methods in com.hazelcast.mapreduce that return Address
 Address JobPartitionState.getOwner()
          Returns the owner of this partition
 

Uses of Address in com.hazelcast.mapreduce.impl
 

Methods in com.hazelcast.mapreduce.impl that return Address
 Address MapReduceService.getKeyMember(Object key)
           
 Address MapReduceService.getLocalAddress()
           
 

Methods in com.hazelcast.mapreduce.impl that return types with arguments of type Address
static
<K,V> Map<Address,Map<K,V>>
MapReduceUtil.mapResultToMember(JobSupervisor supervisor, Map<K,V> result)
           
 

Methods in com.hazelcast.mapreduce.impl with parameters of type Address
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)
           
 

Method parameters in com.hazelcast.mapreduce.impl with type arguments of type Address
 boolean MapReduceService.checkAssignedMembersAvailable(Collection<Address> assignedMembers)
           
 

Uses of Address in com.hazelcast.mapreduce.impl.notification
 

Methods in com.hazelcast.mapreduce.impl.notification that return Address
 Address MemberAwareMapReduceNotification.getAddress()
           
 Address LastChunkNotification.getSender()
           
 

Constructors in com.hazelcast.mapreduce.impl.notification with parameters of type Address
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)
           
 

Uses of Address in com.hazelcast.mapreduce.impl.operation
 

Methods in com.hazelcast.mapreduce.impl.operation that return types with arguments of type Address
 Map<Object,Address> KeysAssignmentResult.getAssignment()
           
 

Constructor parameters in com.hazelcast.mapreduce.impl.operation with type arguments of type Address
KeysAssignmentResult(RequestPartitionResult.ResultState resultState, Map<Object,Address> assignment)
           
 

Uses of Address in com.hazelcast.mapreduce.impl.task
 

Methods in com.hazelcast.mapreduce.impl.task that return Address
 Address JobSupervisor.assignKeyReducerAddress(Object key)
           
 Address JobTaskConfiguration.getJobOwner()
           
 Address JobSupervisor.getJobOwner()
           
 Address JobPartitionStateImpl.getOwner()
           
 Address JobSupervisor.getReducerAddressByKey(Object key)
           
 

Methods in com.hazelcast.mapreduce.impl.task that return types with arguments of type Address
 Collection<Address> JobSupervisor.getReducerEventInterests(int partitionId)
           
 

Methods in com.hazelcast.mapreduce.impl.task with parameters of type Address
 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)
           
 

Method parameters in com.hazelcast.mapreduce.impl.task with type arguments of type Address
 void JobSupervisor.registerReducerEventInterests(int partitionId, Set<Address> remoteReducers)
           
 

Constructors in com.hazelcast.mapreduce.impl.task with parameters of type Address
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)
           
 

Uses of Address in com.hazelcast.nio
 

Methods in com.hazelcast.nio that return Address
 Address Connection.getEndPoint()
          Gets the Address of the other side of this Connection.
 Address NodeIOService.getThisAddress()
           
 Address IOService.getThisAddress()
           
 

Methods in com.hazelcast.nio with parameters of type Address
 Connection ConnectionManager.getConnection(Address address)
           
 Connection ConnectionManager.getOrConnect(Address address)
           
 Connection ConnectionManager.getOrConnect(Address address, boolean silent)
           
 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)
           
 

Constructors in com.hazelcast.nio with parameters of type Address
Address(Address address)
           
 

Uses of Address in com.hazelcast.nio.tcp
 

Methods in com.hazelcast.nio.tcp that return Address
 Address TcpIpConnectionMonitor.getEndPoint()
           
 Address TcpIpConnection.getEndPoint()
           
 

Methods in com.hazelcast.nio.tcp with parameters of type Address
 boolean TcpIpConnectionManager.bind(TcpIpConnection connection, Address remoteEndPoint, Address localEndpoint, boolean reply)
           
 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)
           
 

Constructors in com.hazelcast.nio.tcp with parameters of type Address
SocketConnector(TcpIpConnectionManager connectionManager, Address address, boolean silent)
           
TcpIpConnectionMonitor(TcpIpConnectionManager connectionManager, Address endPoint)
           
 

Uses of Address in com.hazelcast.partition
 

Methods in com.hazelcast.partition that return Address
 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()
           
 

Methods in com.hazelcast.partition that return types with arguments of type Address
 Map<Address,List<Integer>> InternalPartitionService.getMemberPartitionsMap()
          Gets member partition IDs.
 

Methods in com.hazelcast.partition with parameters of type Address
 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)
           
 

Method parameters in com.hazelcast.partition with type arguments of type Address
protected  void PartitionRuntimeState.addMemberInfo(MemberInfo memberInfo, Map<Address,Integer> addressIndexes, int memberIndex)
           
protected  void PartitionRuntimeState.setPartitions(InternalPartition[] partitions, Map<Address,Integer> addressIndexes)
           
 

Constructors in com.hazelcast.partition with parameters of type Address
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)
           
 

Uses of Address in com.hazelcast.partition.client
 

Methods in com.hazelcast.partition.client that return Address
 Address[] PartitionsResponse.getMembers()
           
 

Constructors in com.hazelcast.partition.client with parameters of type Address
PartitionsResponse(Address[] members, int[] ownerIndexes)
           
 

Uses of Address in com.hazelcast.partition.impl
 

Methods in com.hazelcast.partition.impl that return Address
 Address InternalPartitionServiceImpl.getPartitionOwner(int partitionId)
           
 Address InternalPartitionServiceImpl.getPartitionOwnerOrWait(int partition)
           
 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)
           
 

Methods in com.hazelcast.partition.impl that return types with arguments of type Address
 Map<Address,List<Integer>> InternalPartitionServiceImpl.getMemberPartitionsMap()
           
 

Methods in com.hazelcast.partition.impl with parameters of type Address
 MemberImpl InternalPartitionServiceImpl.getMember(Address address)
           
 List<Integer> InternalPartitionServiceImpl.getMemberPartitions(Address target)
           
 

Uses of Address in com.hazelcast.replicatedmap.impl.record
 

Methods in com.hazelcast.replicatedmap.impl.record with parameters of type Address
 void ReplicationPublisher.queuePreProvision(Address callerAddress, int chunkSize)
           
 

Uses of Address in com.hazelcast.spi
 

Fields in com.hazelcast.spi declared as Address
protected  Address InvocationBuilder.target
           
 

Methods in com.hazelcast.spi that return Address
 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.
 

Methods in com.hazelcast.spi with parameters of type Address
 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)
           
 

Constructors in com.hazelcast.spi with parameters of type Address
InvocationBuilder(NodeEngineImpl nodeEngine, String serviceName, Operation op, int partitionId, Address target)
          Creates an InvocationBuilder
 

Uses of Address in com.hazelcast.spi.exception
 

Methods in com.hazelcast.spi.exception that return Address
 Address WrongTargetException.getTarget()
           
 

Constructors in com.hazelcast.spi.exception with parameters of type Address
CallerNotMemberException(Address target, 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)
           
 

Uses of Address in com.hazelcast.spi.impl
 

Methods in com.hazelcast.spi.impl that return Address
 Address NodeEngineImpl.getMasterAddress()
           
 Address PortablePartitionLostEvent.getSource()
           
 Address NodeEngineImpl.getThisAddress()
           
 

Constructors in com.hazelcast.spi.impl with parameters of type Address
PortablePartitionLostEvent(int partitionId, int lostBackupCount, Address source)
           
 

Uses of Address in com.hazelcast.spi.impl.eventservice.impl
 

Methods in com.hazelcast.spi.impl.eventservice.impl that return Address
 Address Registration.getSubscriber()
           
 

Constructors in com.hazelcast.spi.impl.eventservice.impl with parameters of type Address
Registration(String id, String serviceName, String topic, EventFilter filter, Address subscriber, Object listener, boolean localOnly)
           
 

Uses of Address in com.hazelcast.spi.impl.operationexecutor.classic
 

Constructors in com.hazelcast.spi.impl.operationexecutor.classic with parameters of type Address
ClassicOperationExecutor(GroupProperties properties, LoggingService loggerService, Address thisAddress, OperationRunnerFactory operationRunnerFactory, ResponsePacketHandler responsePacketHandler, HazelcastThreadGroup hazelcastThreadGroup, NodeExtension nodeExtension)
           
 

Uses of Address in com.hazelcast.spi.impl.operationservice
 

Methods in com.hazelcast.spi.impl.operationservice with parameters of type Address
<V> void
InternalOperationService.asyncInvokeOnTarget(String serviceName, Operation op, Address target, ExecutionCallback<V> callback)
           
 

Uses of Address in com.hazelcast.spi.impl.operationservice.impl
 

Methods in com.hazelcast.spi.impl.operationservice.impl that return Address
 Address TargetInvocation.getTarget()
           
 Address PartitionInvocation.getTarget()
           
 

Methods in com.hazelcast.spi.impl.operationservice.impl with parameters of type Address
<V> void
OperationServiceImpl.asyncInvokeOnTarget(String serviceName, Operation op, Address target, ExecutionCallback<V> callback)
           
 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.
 boolean OperationServiceImpl.send(Operation op, Address target)
           
 boolean OperationServiceImpl.send(Response response, Address target)
           
 

Constructors in com.hazelcast.spi.impl.operationservice.impl with parameters of type Address
InvocationBuilderImpl(NodeEngineImpl nodeEngine, String serviceName, Operation op, Address target)
           
TargetInvocation(NodeEngineImpl nodeEngine, String serviceName, Operation op, Address target, int tryCount, long tryPauseMillis, long callTimeout, Object callback, boolean resultDeserialized)
           
 

Uses of Address in com.hazelcast.spi.impl.operationservice.impl.operations
 

Constructors in com.hazelcast.spi.impl.operationservice.impl.operations with parameters of type Address
Backup(Data backupOp, Address originalCaller, long[] replicaVersions, boolean sync)
           
 

Uses of Address in com.hazelcast.spi.impl.transceiver
 

Methods in com.hazelcast.spi.impl.transceiver with parameters of type Address
 boolean PacketTransceiver.transmit(Packet packet, Address target)
          Transmits a packet to a certain address.
 

Uses of Address in com.hazelcast.spi.impl.transceiver.impl
 

Methods in com.hazelcast.spi.impl.transceiver.impl with parameters of type Address
 boolean PacketTransceiverImpl.transmit(Packet packet, Address target)
          Retries sending packet maximum 5 times until connection to target becomes available.
 

Uses of Address in com.hazelcast.spi.impl.waitnotifyservice.impl
 

Methods in com.hazelcast.spi.impl.waitnotifyservice.impl with parameters of type Address
 void WaitNotifyServiceImpl.onPartitionMigrate(Address thisAddress, MigrationInfo migrationInfo)
           
 

Uses of Address in com.hazelcast.topic.impl
 

Fields in com.hazelcast.topic.impl declared as Address
 Address TopicEvent.publisherAddress
           
 

Constructors in com.hazelcast.topic.impl with parameters of type Address
TopicEvent(String name, Data data, Address publisherAddress)
           
 

Uses of Address in com.hazelcast.topic.impl.reliable
 

Methods in com.hazelcast.topic.impl.reliable that return Address
 Address ReliableTopicMessage.getPublisherAddress()
           
 

Constructors in com.hazelcast.topic.impl.reliable with parameters of type Address
ReliableTopicMessage(Data payload, Address publisherAddress)
           
 

Uses of Address in com.hazelcast.transaction.client
 

Methods in com.hazelcast.transaction.client that return types with arguments of type Address
 Collection<Address> CollectXATransactionsRequest.getTargets()
           
 

Method parameters in com.hazelcast.transaction.client with type arguments of type Address
protected  Object CollectXATransactionsRequest.reduce(Map<Address,Object> map)
           
 

Uses of Address in com.hazelcast.util
 

Methods in com.hazelcast.util with parameters of type Address
static String UuidUtil.createClientUuid(Address endpoint)
           
static String UuidUtil.createMemberUuid(Address endpoint)
           
 

Uses of Address in com.hazelcast.wan.impl
 

Methods in com.hazelcast.wan.impl with parameters of type Address
 boolean WanNoDelayReplication.checkAuthorization(String groupName, String groupPassword, Address target)
           
 



Copyright © 2015 Hazelcast, Inc.. All Rights Reserved.