Package | Description |
---|---|
com.hazelcast.client |
This package contains the serverside client functionality
|
com.hazelcast.client.connection | |
com.hazelcast.client.connection.nio | |
com.hazelcast.client.spi | |
com.hazelcast.client.spi.impl | |
com.hazelcast.client.util | |
com.hazelcast.cluster | |
com.hazelcast.collection | |
com.hazelcast.executor |
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.client |
This package contains client requests for the IExecutorService.
|
com.hazelcast.instance | |
com.hazelcast.management | |
com.hazelcast.management.request | |
com.hazelcast.map |
Contains Hazelcast map module classes.
|
com.hazelcast.map.client | |
com.hazelcast.mapreduce |
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster. |
com.hazelcast.mapreduce.impl |
This package contains the default implementation for the map reduce framework
internals.
|
com.hazelcast.mapreduce.impl.notification |
This package contains all remote node notifications
|
com.hazelcast.mapreduce.impl.operation |
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
|
com.hazelcast.mapreduce.impl.task |
This package contains the base implementation for a standard map reduce job.
|
com.hazelcast.monitor |
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
|
com.hazelcast.monitor.impl |
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
|
com.hazelcast.multimap | |
com.hazelcast.nio | |
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.queue | |
com.hazelcast.spi |
Provides interfaces/classes for Hazelcast SPI.
|
com.hazelcast.spi.exception | |
com.hazelcast.spi.impl | |
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 |
Modifier and Type | Method and Description |
---|---|
Address |
ClientEngine.getMasterAddress() |
Address |
ClientEngineImpl.getMasterAddress() |
abstract Address |
TargetClientRequest.getTarget() |
Address |
ClientEngine.getThisAddress() |
Address |
ClientEngineImpl.getThisAddress() |
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) |
Modifier and Type | Method and Description |
---|---|
Address |
Router.next() |
Modifier and Type | Method and Description |
---|---|
ClientConnection |
ClientConnectionManager.ownerConnection(Address address) |
ClientConnection |
ClientConnectionManager.tryToConnect(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientConnection.getEndPoint() |
Address |
ClientConnection.getRemoteEndpoint() |
Modifier and Type | Method and Description |
---|---|
ClientConnection |
ClientConnectionManagerImpl.ownerConnection(Address address) |
void |
ClientConnection.setRemoteEndpoint(Address remoteEndpoint) |
ClientConnection |
ClientConnectionManagerImpl.tryToConnect(Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientClusterService.getMasterAddress() |
Address |
ClientPartitionService.getPartitionOwner(int partitionId) |
Modifier and Type | Method and Description |
---|---|
MemberImpl |
ClientClusterService.getMember(Address address) |
protected <T> T |
ClientProxy.invoke(ClientRequest req,
Address address) |
<T> ICompletableFuture<T> |
ClientInvocationService.invokeOnTarget(ClientRequest request,
Address target) |
<T> ICompletableFuture<T> |
ClientInvocationService.invokeOnTarget(ClientRequest request,
Address target,
EventHandler handler) |
Modifier and Type | Method and Description |
---|---|
Address |
ClientClusterServiceImpl.getMasterAddress() |
Address |
ClientPartitionServiceImpl.getPartitionOwner(int partitionId) |
Modifier and Type | Method and Description |
---|---|
MemberImpl |
ClientClusterServiceImpl.getMember(Address address) |
<T> ICompletableFuture<T> |
ClientInvocationServiceImpl.invokeOnTarget(ClientRequest request,
Address target) |
<T> ICompletableFuture<T> |
ClientInvocationServiceImpl.invokeOnTarget(ClientRequest request,
Address target,
EventHandler handler) |
Constructor and Description |
---|
ClientCancellableDelegatingFuture(ICompletableFuture future,
ClientContext context,
String uuid,
Address target,
int partitionId) |
ClientCancellableDelegatingFuture(ICompletableFuture future,
ClientContext context,
String uuid,
Address target,
int partitionId,
V defaultValue) |
Modifier and Type | Field and Description |
---|---|
protected Address |
JoinMessage.address |
protected Address |
SetMasterOperation.masterAddress |
protected Address |
ClusterServiceImpl.thisAddress |
Modifier and Type | Method and Description |
---|---|
Address |
MemberInfo.getAddress() |
Address |
JoinMessage.getAddress() |
Address |
SetMasterOperation.getMasterAddress() |
Address |
ClusterService.getMasterAddress() |
Address |
ClusterServiceImpl.getMasterAddress() |
Address |
AbstractJoiner.getTargetAddress() |
Address |
ClusterService.getThisAddress() |
Address |
ClusterServiceImpl.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
JoinRequest |
ClusterServiceImpl.checkJoinInfo(Address target) |
protected MemberImpl |
ClusterServiceImpl.createMember(Address address,
String nodeUuid,
String ipV6ScopeId,
Map<String,Object> attributes) |
MemberImpl |
ClusterService.getMember(Address address) |
MemberImpl |
ClusterServiceImpl.getMember(Address address) |
void |
ClusterServiceImpl.removeAddress(Address deadAddress) |
boolean |
ClusterServiceImpl.sendJoinRequest(Address toAddress,
boolean withCredentials) |
void |
AbstractJoiner.setTargetAddress(Address targetAddress) |
void |
Joiner.setTargetAddress(Address targetAddress) |
protected void |
AbstractJoiner.startClusterMerge(Address targetAddress) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractJoiner.connectAndSendJoinRequest(Collection<Address> colPossibleAddresses) |
Constructor and Description |
---|
BindOperation(Address localAddress) |
BindOperation(Address localAddress,
Address targetAddress,
boolean replyBack) |
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) |
MemberInfo(Address address) |
MemberInfo(Address address,
String uuid,
Map<String,Object> attributes) |
MemberRemoveOperation(Address deadAddress) |
MergeClustersOperation(Address newTargetAddress) |
PrepareMergeOperation(Address newTargetAddress) |
SetMasterOperation(Address originAddress) |
Constructor and Description |
---|
CollectionEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
Modifier and Type | Method and Description |
---|---|
boolean |
DistributedExecutorService.isOperationExecuting(Address callerAddress,
String callerUuid,
Object identifier) |
Modifier and Type | Method and Description |
---|---|
Address |
TargetCallableRequest.getTarget() |
Constructor and Description |
---|
CancellationRequest(String uuid,
Address target,
boolean interrupt) |
TargetCallableRequest(String name,
String uuid,
Callable callable,
Address target) |
Modifier and Type | Field and Description |
---|---|
Address |
Node.address |
Modifier and Type | Method and Description |
---|---|
Address |
MemberImpl.getAddress() |
Address |
AddressPicker.getBindAddress() |
Address |
Node.getMasterAddress() |
Address |
AddressPicker.getPublicAddress() |
Address |
Node.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Set<Address> |
Node.getFailedConnections() |
Modifier and Type | Method and Description |
---|---|
void |
Node.failedConnection(Address address) |
void |
Node.setMasterAddress(Address master) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
Object |
ManagementCenterService.callOnAddress(Address address,
Operation operation) |
void |
ManagementCenterService.send(Address address,
Operation operation) |
Constructor and Description |
---|
ClusterRuntimeState(Collection<Member> members,
InternalPartition[] partitions,
Collection<MigrationInfo> activeMigrations,
Map<Address,Connection> connections,
Collection<LockResource> locks) |
Modifier and Type | Method and Description |
---|---|
Address |
MapConfigRequest.getTarget() |
Modifier and Type | Method and Description |
---|---|
void |
MapConfigRequest.setTarget(Address target) |
Constructor and Description |
---|
MapConfigRequest(String map,
Address target) |
ThreadDumpRequest(Address target,
boolean dumpDeadlocks) |
Constructor and Description |
---|
ExecuteScriptRequest(String script,
String engine,
Set<Address> targets,
Map<String,Object> bindings) |
Modifier and Type | Field and Description |
---|---|
protected Address |
EventData.caller |
Modifier and Type | Method and Description |
---|---|
Address |
EventData.getCaller() |
Modifier and Type | Method and Description |
---|---|
void |
MapService.publishEvent(Address caller,
String mapName,
EntryEventType eventType,
Data dataKey,
Data dataOldValue,
Data dataValue) |
Constructor and Description |
---|
EventData(String source,
String mapName,
Address caller,
Data dataKey,
Data dataNewValue,
Data dataOldValue,
int eventType) |
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) |
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 <K,V> Map<Address,Map<K,V>> |
MapReduceUtil.mapResultToMember(JobSupervisor supervisor,
Map<K,V> result) |
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,
String name) |
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) |
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 |
MemberState.getAddress() |
Modifier and Type | Method and Description |
---|---|
Address |
MemberStateImpl.getAddress() |
Modifier and Type | Method and Description |
---|---|
void |
MemberStateImpl.setAddress(Address address) |
Modifier and Type | Method and Description |
---|---|
Address |
MultiMapEvent.getCaller() |
Constructor and Description |
---|
MultiMapEvent(String name,
Data key,
Data value,
EntryEventType eventType,
Address caller) |
Modifier and Type | Method and Description |
---|---|
Address |
Connection.getEndPoint()
Gets the of the other side of this Connection.
|
Address |
ConnectionMonitor.getEndPoint() |
Address |
TcpIpConnection.getEndPoint() |
Address |
IOService.getThisAddress() |
Address |
NodeIOService.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
Map<Address,Connection> |
TcpIpConnectionManager.getReadonlyConnectionMap() |
Map<Address,Connection> |
ConnectionManager.getReadonlyConnectionMap() |
Modifier and Type | Method and Description |
---|---|
boolean |
TcpIpConnectionManager.bind(TcpIpConnection connection,
Address remoteEndPoint,
Address localEndpoint,
boolean replyBack) |
Connection |
TcpIpConnectionManager.getConnection(Address address) |
Connection |
ConnectionManager.getConnection(Address address) |
Connection |
TcpIpConnectionManager.getOrConnect(Address address) |
Connection |
ConnectionManager.getOrConnect(Address address) |
Connection |
TcpIpConnectionManager.getOrConnect(Address address,
boolean silent) |
Connection |
ConnectionManager.getOrConnect(Address address,
boolean silent) |
void |
IOService.onDisconnect(Address endpoint) |
void |
NodeIOService.onDisconnect(Address endpoint) |
void |
IOService.onFailedConnection(Address address) |
void |
NodeIOService.onFailedConnection(Address address) |
void |
IOService.removeEndpoint(Address endpoint) |
void |
NodeIOService.removeEndpoint(Address endPoint) |
void |
TcpIpConnection.setEndPoint(Address endPoint) |
void |
IOService.shouldConnectTo(Address address) |
void |
NodeIOService.shouldConnectTo(Address address) |
Constructor and Description |
---|
Address(Address address) |
ConnectionMonitor(TcpIpConnectionManager connectionManager,
Address endPoint) |
SocketConnector(TcpIpConnectionManager connectionManager,
Address address,
boolean silent) |
Modifier and Type | Method and Description |
---|---|
Address |
MigrationInfo.getDestination() |
Address |
PartitionRuntimeState.getEndpoint() |
Address |
MigrationInfo.getMaster() |
Address |
InternalPartition.getOwner()
Returns the Address of the owner of this partition.
|
Address |
InternalPartitionService.getPartitionOwner(int partitionId) |
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() |
Modifier and Type | Method and Description |
---|---|
Member |
InternalPartitionService.getMember(Address address) |
List<Integer> |
InternalPartitionService.getMemberPartitions(Address target) |
boolean |
InternalPartition.isOwnerOrBackup(Address address) |
void |
PartitionRuntimeState.setEndpoint(Address endpoint) |
void |
MigrationInfo.setMaster(Address master) |
Modifier and Type | Method and Description |
---|---|
protected void |
PartitionRuntimeState.addMemberInfo(MemberInfo memberInfo,
Map<Address,Integer> addressIndexes,
int memberIndex) |
protected void |
PartitionRuntimeState.setPartitions(InternalPartition[] partitions,
Map<Address,Integer> addressIndexes) |
Constructor and Description |
---|
MigrationInfo(int partitionId,
Address source,
Address destination) |
PartitionInfo(int partitionId,
Address[] addresses) |
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[][] |
PartitionStateGeneratorImpl.initialize(Collection<MemberGroup> memberGroups,
int partitionCount) |
Address[][] |
PartitionStateGenerator.initialize(Collection<MemberGroup> groups,
int partitionCount)
Returns the initial layout for the partitions.
|
Address[][] |
PartitionStateGeneratorImpl.reArrange(Collection<MemberGroup> memberGroups,
InternalPartition[] currentState) |
Address[][] |
PartitionStateGenerator.reArrange(Collection<MemberGroup> groups,
InternalPartition[] currentState)
Rearranges the partition layout.
|
Modifier and Type | Method and Description |
---|---|
Map<Address,List<Integer>> |
InternalPartitionServiceImpl.getMemberPartitionsMap() |
Modifier and Type | Method and Description |
---|---|
MemberImpl |
InternalPartitionServiceImpl.getMember(Address address) |
List<Integer> |
InternalPartitionServiceImpl.getMemberPartitions(Address target) |
Constructor and Description |
---|
PartitionReplicaChangeEvent(int partitionId,
int replicaIndex,
Address oldAddress,
Address newAddress) |
Constructor and Description |
---|
QueueEvent(String name,
Data data,
ItemEventType eventType,
Address caller) |
Modifier and Type | Field and Description |
---|---|
protected Address |
InvocationBuilder.target |
Modifier and Type | Method and Description |
---|---|
Address |
Operation.getCallerAddress() |
Address |
NodeEngine.getMasterAddress() |
Address |
EventRegistration.getSubscriber() |
Address |
InvocationBuilder.getTarget() |
Address |
NodeEngine.getThisAddress() |
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) |
static void |
OperationAccessor.setCallerAddress(Operation op,
Address caller) |
Constructor and Description |
---|
InvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
int partitionId,
Address target) |
Modifier and Type | Method and Description |
---|---|
Address |
WrongTargetException.getTarget() |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
Address |
NodeEngineImpl.getMasterAddress() |
Address |
EventServiceImpl.Registration.getSubscriber() |
Address |
BasicTargetInvocation.getTarget() |
Address |
BasicPartitionInvocation.getTarget() |
Address |
NodeEngineImpl.getThisAddress() |
Modifier and Type | Method and Description |
---|---|
boolean |
NodeEngineImpl.send(Packet packet,
Address target)
Retries sending packet maximum 5 times until connection to target becomes available.
|
Constructor and Description |
---|
BasicInvocationBuilder(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target) |
BasicTargetInvocation(NodeEngineImpl nodeEngine,
String serviceName,
Operation op,
Address target,
int tryCount,
long tryPauseMillis,
long callTimeout,
Callback<Object> callback,
String executorName,
boolean resultDeserialized) |
Registration(String id,
String serviceName,
String topic,
EventFilter filter,
Address subscriber,
Object listener,
boolean localOnly) |
Modifier and Type | Method and Description |
---|---|
static String |
UuidUtil.createClientUuid(Address endpoint) |
static String |
UuidUtil.createMemberUuid(Address endpoint) |
Modifier and Type | Method and Description |
---|---|
boolean |
WanNoDelayReplication.checkAuthorization(String groupName,
String groupPassword,
Address target) |
Copyright © 2014 Hazelcast, Inc.. All rights reserved.