com.hazelcast.client
Class HazelcastClientProxy

java.lang.Object
  extended by com.hazelcast.client.HazelcastClientProxy
All Implemented Interfaces:
HazelcastInstance

public final class HazelcastClientProxy
extends Object
implements HazelcastInstance


Method Summary
 String addDistributedObjectListener(DistributedObjectListener distributedObjectListener)
          Adds a Distributed Object listener which will be notified when a new DistributedObject will be created or destroyed.
<T> T
executeTransaction(TransactionalTask<T> task)
          Executes given transactional task in current thread using default options and returns the result of the task.
<T> T
executeTransaction(TransactionOptions options, TransactionalTask<T> task)
          Executes given transactional task in current thread using given options and returns the result of the task.
 IAtomicLong getAtomicLong(String name)
          Creates cluster-wide atomic long.
<E> IAtomicReference<E>
getAtomicReference(String name)
          Creates cluster-wide atomic reference.
 ClientConfig getClientConfig()
           
 ClientService getClientService()
          Returns the client service of this Hazelcast instance.
 Cluster getCluster()
          Returns the Cluster that this Hazelcast instance is part of.
 Config getConfig()
          Returns the configuration of this Hazelcast instance.
 ICountDownLatch getCountDownLatch(String name)
          Creates cluster-wide CountDownLatch.
<T extends DistributedObject>
T
getDistributedObject(String serviceName, Object id)
          Deprecated. 
<T extends DistributedObject>
T
getDistributedObject(String serviceName, String name)
           
 Collection<DistributedObject> getDistributedObjects()
          Returns all DistributedObject's such as; queue, map, set, list, topic, lock, multimap.
 IExecutorService getExecutorService(String name)
          Returns the distributed executor service for the given name.
 IdGenerator getIdGenerator(String name)
          Creates cluster-wide unique IDs.
 JobTracker getJobTracker(String name)
          Returns the job tracker instance with the specified name.
 LifecycleService getLifecycleService()
          Returns the lifecycle service for this instance.
<E> IList<E>
getList(String name)
          Returns the distributed list instance with the specified name.
 Client getLocalEndpoint()
          Returns the local Endpoint which this HazelcastInstance is belongs to.
 ILock getLock(Object key)
           
 ILock getLock(String key)
          Returns the distributed lock instance for the specified key object.
 com.hazelcast.logging.LoggingService getLoggingService()
          Returns the logging service of this Hazelcast instance.
<K,V> IMap<K,V>
getMap(String name)
          Returns the distributed map instance with the specified name.
<K,V> MultiMap<K,V>
getMultiMap(String name)
          Returns the distributed multimap instance with the specified name.
 String getName()
          Returns the name of this Hazelcast instance
 PartitionService getPartitionService()
          Returns the partition service of this Hazelcast instance.
<E> IQueue<E>
getQueue(String name)
          Returns the distributed queue instance with the specified name.
 ISemaphore getSemaphore(String name)
          Creates cluster-wide semaphore.
 SerializationService getSerializationService()
           
<E> ISet<E>
getSet(String name)
          Returns the distributed set instance with the specified name.
<E> ITopic<E>
getTopic(String name)
          Returns the distributed topic instance with the specified name.
 ConcurrentMap<String,Object> getUserContext()
          Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
 TransactionContext newTransactionContext()
          Creates a new TransactionContext associated with the current thread using default options.
 TransactionContext newTransactionContext(TransactionOptions options)
          Creates a new TransactionContext associated with the current thread with given options.
 boolean removeDistributedObjectListener(String registrationId)
          Removes the specified Distributed Object listener.
 void shutdown()
          Shuts down this HazelcastInstance.
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Method Detail

getConfig

public Config getConfig()
Description copied from interface: HazelcastInstance
Returns the configuration of this Hazelcast instance.

Specified by:
getConfig in interface HazelcastInstance
Returns:
configuration of this Hazelcast instance

getName

public String getName()
Description copied from interface: HazelcastInstance
Returns the name of this Hazelcast instance

Specified by:
getName in interface HazelcastInstance
Returns:
name of this Hazelcast instance

getQueue

public <E> IQueue<E> getQueue(String name)
Description copied from interface: HazelcastInstance
Returns the distributed queue instance with the specified name.

Specified by:
getQueue in interface HazelcastInstance
Parameters:
name - name of the distributed queue
Returns:
distributed queue instance with the specified name

getTopic

public <E> ITopic<E> getTopic(String name)
Description copied from interface: HazelcastInstance
Returns the distributed topic instance with the specified name.

Specified by:
getTopic in interface HazelcastInstance
Parameters:
name - name of the distributed topic
Returns:
distributed topic instance with the specified name

getSet

public <E> ISet<E> getSet(String name)
Description copied from interface: HazelcastInstance
Returns the distributed set instance with the specified name.

Specified by:
getSet in interface HazelcastInstance
Parameters:
name - name of the distributed set
Returns:
distributed set instance with the specified name

getList

public <E> IList<E> getList(String name)
Description copied from interface: HazelcastInstance
Returns the distributed list instance with the specified name. Index based operations on the list are not supported.

Specified by:
getList in interface HazelcastInstance
Parameters:
name - name of the distributed list
Returns:
distributed list instance with the specified name

getMap

public <K,V> IMap<K,V> getMap(String name)
Description copied from interface: HazelcastInstance
Returns the distributed map instance with the specified name.

Specified by:
getMap in interface HazelcastInstance
Parameters:
name - name of the distributed map
Returns:
distributed map instance with the specified name

getMultiMap

public <K,V> MultiMap<K,V> getMultiMap(String name)
Description copied from interface: HazelcastInstance
Returns the distributed multimap instance with the specified name.

Specified by:
getMultiMap in interface HazelcastInstance
Parameters:
name - name of the distributed multimap
Returns:
distributed multimap instance with the specified name

getJobTracker

public JobTracker getJobTracker(String name)
Description copied from interface: HazelcastInstance
Returns the job tracker instance with the specified name.

Specified by:
getJobTracker in interface HazelcastInstance
Parameters:
name - name of the job tracker
Returns:
job tracker instance with specified name

getLock

public ILock getLock(Object key)
Specified by:
getLock in interface HazelcastInstance

getLock

public ILock getLock(String key)
Description copied from interface: HazelcastInstance
Returns the distributed lock instance for the specified key object. The specified object is considered to be the key for this lock. So keys are considered equals cluster-wide as long as they are serialized to the same byte array such as String, long, Integer.

Locks are fail-safe. If a member holds a lock and some of the members go down, cluster will keep your locks safe and available. Moreover, when a member leaves the cluster, all the locks acquired by this dead member will be removed so that these locks can be available for live members immediately.

 Lock lock = hazelcastInstance.getLock("PROCESS_LOCK");
 lock.lock();
 try {
   // process
 } finally {
   lock.unlock();
 }
 

Specified by:
getLock in interface HazelcastInstance
Parameters:
key - key of the lock instance
Returns:
distributed lock instance for the specified key.

getCluster

public Cluster getCluster()
Description copied from interface: HazelcastInstance
Returns the Cluster that this Hazelcast instance is part of. Cluster interface allows you to add listener for membership events and learn more about the cluster that this Hazelcast instance is part of.

Specified by:
getCluster in interface HazelcastInstance
Returns:
cluster that this Hazelcast instance is part of

getLocalEndpoint

public Client getLocalEndpoint()
Description copied from interface: HazelcastInstance
Returns the local Endpoint which this HazelcastInstance is belongs to.

Returned endpoint will be a Member instance for cluster nodes and a Client instance for clients.

Specified by:
getLocalEndpoint in interface HazelcastInstance
Returns:
local endpoint
See Also:
Member, Client

getExecutorService

public IExecutorService getExecutorService(String name)
Description copied from interface: HazelcastInstance
Returns the distributed executor service for the given name. Executor service enables you to run your Runnables and Callables on the Hazelcast cluster.

Note: Note that it don't support invokeAll/Any and don't have standard shutdown behavior

Specified by:
getExecutorService in interface HazelcastInstance
Parameters:
name - name of the executor service
Returns:
executor service for the given name

executeTransaction

public <T> T executeTransaction(TransactionalTask<T> task)
                     throws TransactionException
Description copied from interface: HazelcastInstance
Executes given transactional task in current thread using default options and returns the result of the task.

Specified by:
executeTransaction in interface HazelcastInstance
Type Parameters:
T - return type of task
Parameters:
task - task to be executed
Returns:
returns result of transactional task
Throws:
TransactionException - if an error occurs during transaction.

executeTransaction

public <T> T executeTransaction(TransactionOptions options,
                                TransactionalTask<T> task)
                     throws TransactionException
Description copied from interface: HazelcastInstance
Executes given transactional task in current thread using given options and returns the result of the task.

Specified by:
executeTransaction in interface HazelcastInstance
Type Parameters:
T - return type of task
Parameters:
options - options for this transactional task
task - task to be executed
Returns:
returns result of transactional task
Throws:
TransactionException - if an error occurs during transaction.

newTransactionContext

public TransactionContext newTransactionContext()
Description copied from interface: HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.

Specified by:
newTransactionContext in interface HazelcastInstance
Returns:
new TransactionContext

newTransactionContext

public TransactionContext newTransactionContext(TransactionOptions options)
Description copied from interface: HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.

Specified by:
newTransactionContext in interface HazelcastInstance
Parameters:
options - options for this transaction
Returns:
new TransactionContext

getIdGenerator

public IdGenerator getIdGenerator(String name)
Description copied from interface: HazelcastInstance
Creates cluster-wide unique IDs. Generated IDs are long type primitive values between 0 and Long.MAX_VALUE . Id generation occurs almost at the speed of AtomicLong.incrementAndGet() . Generated IDs are unique during the life cycle of the cluster. If the entire cluster is restarted, IDs start from 0 again.

Specified by:
getIdGenerator in interface HazelcastInstance
Parameters:
name - name of the IdGenerator
Returns:
IdGenerator for the given name

getAtomicLong

public IAtomicLong getAtomicLong(String name)
Description copied from interface: HazelcastInstance
Creates cluster-wide atomic long. Hazelcast IAtomicLong is distributed implementation of java.util.concurrent.atomic.AtomicLong.

Specified by:
getAtomicLong in interface HazelcastInstance
Parameters:
name - name of the IAtomicLong proxy
Returns:
IAtomicLong proxy for the given name

getAtomicReference

public <E> IAtomicReference<E> getAtomicReference(String name)
Description copied from interface: HazelcastInstance
Creates cluster-wide atomic reference. Hazelcast IAtomicReference is distributed implementation of java.util.concurrent.atomic.AtomicReference.

Specified by:
getAtomicReference in interface HazelcastInstance
Parameters:
name - name of the IAtomicReference proxy
Returns:
IAtomicReference proxy for the given name

getCountDownLatch

public ICountDownLatch getCountDownLatch(String name)
Description copied from interface: HazelcastInstance
Creates cluster-wide CountDownLatch. Hazelcast ICountDownLatch is distributed implementation of java.util.concurrent.CountDownLatch.

Specified by:
getCountDownLatch in interface HazelcastInstance
Parameters:
name - name of the ICountDownLatch proxy
Returns:
ICountDownLatch proxy for the given name

getSemaphore

public ISemaphore getSemaphore(String name)
Description copied from interface: HazelcastInstance
Creates cluster-wide semaphore. Hazelcast ISemaphore is distributed implementation of java.util.concurrent.Semaphore.

Specified by:
getSemaphore in interface HazelcastInstance
Parameters:
name - name of the ISemaphore proxy
Returns:
ISemaphore proxy for the given name

getDistributedObjects

public Collection<DistributedObject> getDistributedObjects()
Description copied from interface: HazelcastInstance
Returns all DistributedObject's such as; queue, map, set, list, topic, lock, multimap.

Specified by:
getDistributedObjects in interface HazelcastInstance
Returns:
the collection of instances created by Hazelcast.

addDistributedObjectListener

public String addDistributedObjectListener(DistributedObjectListener distributedObjectListener)
Description copied from interface: HazelcastInstance
Adds a Distributed Object listener which will be notified when a new DistributedObject will be created or destroyed.

Specified by:
addDistributedObjectListener in interface HazelcastInstance
Parameters:
distributedObjectListener - instance listener
Returns:
returns registration id.

removeDistributedObjectListener

public boolean removeDistributedObjectListener(String registrationId)
Description copied from interface: HazelcastInstance
Removes the specified Distributed Object listener. Returns silently if specified instance listener doesn't exist.

Specified by:
removeDistributedObjectListener in interface HazelcastInstance
Parameters:
registrationId - Id of listener registration.
Returns:
true if registration is removed, false otherwise

getPartitionService

public PartitionService getPartitionService()
Description copied from interface: HazelcastInstance
Returns the partition service of this Hazelcast instance. InternalPartitionService allows you to introspect current partitions in the cluster, partition owner members and listen for partition migration events.

Specified by:
getPartitionService in interface HazelcastInstance
Returns:
partition service

getClientService

public ClientService getClientService()
Description copied from interface: HazelcastInstance
Returns the client service of this Hazelcast instance. Client service allows you to get information about connected clients.

Specified by:
getClientService in interface HazelcastInstance
Returns:
the ClientService.

getLoggingService

public com.hazelcast.logging.LoggingService getLoggingService()
Description copied from interface: HazelcastInstance
Returns the logging service of this Hazelcast instance. LoggingService allows you to listen for LogEvents generated by Hazelcast runtime. You can log the events somewhere or take action base on the message.

Specified by:
getLoggingService in interface HazelcastInstance
Returns:
logging service

getLifecycleService

public LifecycleService getLifecycleService()
Description copied from interface: HazelcastInstance
Returns the lifecycle service for this instance. LifecycleService allows you to shutdown this HazelcastInstance and listen for the lifecycle events.

Specified by:
getLifecycleService in interface HazelcastInstance
Returns:
lifecycle service

getDistributedObject

@Deprecated
public <T extends DistributedObject> T getDistributedObject(String serviceName,
                                                                       Object id)
Deprecated. 

Specified by:
getDistributedObject in interface HazelcastInstance
Type Parameters:
T - type of the DistributedObject
Parameters:
serviceName - name of the service
id - identifier of the object
Returns:
DistributedObject created by the service

getDistributedObject

public <T extends DistributedObject> T getDistributedObject(String serviceName,
                                                            String name)
Specified by:
getDistributedObject in interface HazelcastInstance
Type Parameters:
T - type of the DistributedObject
Parameters:
serviceName - name of the service
name - name of the object
Returns:
DistributedObject created by the service

getUserContext

public ConcurrentMap<String,Object> getUserContext()
Description copied from interface: HazelcastInstance
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance. This can be used to store dependencies that otherwise are hard to obtain. HazelcastInstance can be obtained by implementing HazelcastInstanceAware interface when submitting a Runnable/Callable to Hazelcast ExecutorService. By storing the dependencies in the user-context, they can be retrieved as soon as you have a reference to the HazelcastInstance.

This structure is purely local and Hazelcast remains agnostic abouts its content.

Specified by:
getUserContext in interface HazelcastInstance
Returns:
the user context.

getClientConfig

public ClientConfig getClientConfig()

shutdown

public final void shutdown()
Description copied from interface: HazelcastInstance
Shuts down this HazelcastInstance. For more information see LifecycleService.shutdown().

Specified by:
shutdown in interface HazelcastInstance

getSerializationService

public final SerializationService getSerializationService()


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