Package | Description |
---|---|
com.hazelcast.client |
This package contains the serverside client functionality
|
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.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.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.core |
Provides core API interfaces/classes.
|
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.jet.core |
Jet's Core API.
|
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.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.scheduledexecutor |
This package contains ScheduledExecutorService functionality for Hazelcast.
|
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.partition |
Contains the SPI for partition logic for Hazelcast.
|
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 |
---|---|
Address |
ClientEngine.getMasterAddress() |
Address |
ClientEngine.getThisAddress() |
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 |
---|---|
Collection<Address> |
AddressProvider.loadAddresses() |
Modifier and Type | Method and Description |
---|---|
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
|
Modifier and Type | Method and Description |
---|---|
Address |
ClientConnection.getEndPoint() |
Address |
ClientConnectionManagerImpl.getOwnerConnectionAddress() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultClientConnectionStrategy.beforeGetConnection(Address target) |
void |
DefaultClientConnectionStrategy.beforeOpenConnection(Address target) |
protected ClientConnection |
ClientConnectionManagerImpl.createSocketConnection(Address address) |
Connection |
ClientConnectionManagerImpl.getActiveConnection(Address target) |
Connection |
ClientConnectionManagerImpl.getOrConnect(Address address) |
Connection |
ClientConnectionManagerImpl.getOrTriggerConnect(Address target,
boolean acquiresResources) |
void |
ClientConnection.setRemoteEndpoint(Address remoteEndpoint) |
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(com.hazelcast.client.impl.protocol.ClientMessage clientMessage,
Address address) |
void |
ClientInvocationService.invokeOnTarget(com.hazelcast.client.spi.impl.ClientInvocation invocation,
Address target) |
Modifier and Type | Method and Description |
---|---|
static Collection<Address> |
AddressHelper.getPossibleSocketAddresses(int port,
String scopedAddress,
int portTryCount) |
static Collection<Address> |
AddressHelper.getSocketAddresses(String 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 |
---|---|
Address |
Member.getAddress()
Returns the Address of this Member.
|
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 |
protected Address |
AbstractMember.address |
Modifier and Type | Method and Description |
---|---|
Address |
AbstractMember.getAddress() |
Address |
DelegatingAddressPicker.getBindAddress() |
Address |
AddressPicker.getBindAddress()
Returns a server socket listener address.
|
Address |
Node.getMasterAddress() |
Address |
DelegatingAddressPicker.getPublicAddress() |
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 |
---|---|
String |
NodeExtension.createMemberUuid(Address address)
Creates a UUID for local member
|
String |
DefaultNodeExtension.createMemberUuid(Address address) |
Constructor and Description |
---|
AbstractMember(Address address,
MemberVersion version,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember,
String uuid) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember,
String uuid,
Map<String,Object> attributes,
boolean liteMember) |
MemberImpl(Address address,
MemberVersion version,
boolean localMember,
String uuid,
Map<String,Object> attributes,
boolean liteMember,
int memberListJoinVersion,
HazelcastInstanceImpl instance) |
Modifier and Type | Method and Description |
---|---|
Function<Address,ProcessorSupplier> |
ProcessorMetaSupplier.get(List<Address> addresses)
Called to create a mapping from member
Address to the
ProcessorSupplier that will be sent to that member. |
Modifier and Type | Method and Description |
---|---|
Function<Address,ProcessorSupplier> |
ProcessorMetaSupplier.get(List<Address> addresses)
Called to create a mapping from member
Address to the
ProcessorSupplier that will be sent to that member. |
static ProcessorMetaSupplier |
ProcessorMetaSupplier.of(DistributedFunction<Address,ProcessorSupplier> addressToSupplier)
Factory method that creates a
ProcessorMetaSupplier from the
supplied function that maps a cluster member address to a ProcessorSupplier . |
static ProcessorMetaSupplier |
ProcessorMetaSupplier.of(DistributedFunction<Address,ProcessorSupplier> addressToSupplier,
int preferredLocalParallelism)
Factory method that creates a
ProcessorMetaSupplier from the
supplied function that maps a cluster member address to a ProcessorSupplier . |
Modifier and Type | Method and Description |
---|---|
Address |
JobPartitionState.getOwner()
Deprecated.
Returns the owner of this partition
|
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,
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 |
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 |
TcpIpConnectionErrorHandler.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 |
---|
TcpIpConnectionErrorHandler(TcpIpConnectionManager connectionManager,
Address endPoint) |
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 |
---|---|
abstract Address |
ScheduledTaskHandler.getAddress()
Returns the address of the member the task is associated with.
|
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.
|
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) |
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 |
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 |
---|---|
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 © 2018 Hazelcast, Inc.. All rights reserved.