Return-Path: Delivered-To: apmail-geronimo-activemq-commits-archive@www.apache.org Received: (qmail 74543 invoked from network); 3 Aug 2006 02:25:57 -0000 Received: from hermes.apache.org (HELO mail.apache.org) (209.237.227.199) by minotaur.apache.org with SMTP; 3 Aug 2006 02:25:57 -0000 Received: (qmail 20599 invoked by uid 500); 3 Aug 2006 02:25:57 -0000 Delivered-To: apmail-geronimo-activemq-commits-archive@geronimo.apache.org Received: (qmail 20562 invoked by uid 500); 3 Aug 2006 02:25:57 -0000 Mailing-List: contact activemq-commits-help@geronimo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: activemq-dev@geronimo.apache.org Delivered-To: mailing list activemq-commits@geronimo.apache.org Received: (qmail 20544 invoked by uid 99); 3 Aug 2006 02:25:57 -0000 Received: from asf.osuosl.org (HELO asf.osuosl.org) (140.211.166.49) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 02 Aug 2006 19:25:57 -0700 X-ASF-Spam-Status: No, hits=-9.4 required=10.0 tests=ALL_TRUSTED,NO_REAL_NAME X-Spam-Check-By: apache.org Received-SPF: pass (asf.osuosl.org: local policy) Received: from [140.211.166.113] (HELO eris.apache.org) (140.211.166.113) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 02 Aug 2006 19:25:50 -0700 Received: by eris.apache.org (Postfix, from userid 65534) id AE5981A981D; Wed, 2 Aug 2006 19:25:30 -0700 (PDT) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r428212 [2/28] - in /incubator/activemq/site/cms: ./ html/ Date: Thu, 03 Aug 2006 02:24:54 -0000 To: activemq-commits@geronimo.apache.org From: jstrachan@apache.org X-Mailer: svnmailer-1.0.8 Message-Id: <20060803022530.AE5981A981D@eris.apache.org> X-Virus-Checked: Checked by ClamAV on apache.org X-Spam-Rating: minotaur.apache.org 1.6.2 0/1000/N Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,224 @@ + + +activemq-cpp: activemq::concurrent::Synchronizable Class Reference + + + + + + + +

activemq::concurrent::Synchronizable Class Reference

#include <Synchronizable.h> +

+

Inheritance diagram for activemq::concurrent::Synchronizable: +

+ +activemq::concurrent::Mutex +activemq::io::InputStream +activemq::io::OutputStream +activemq::transport::FutureResponse +activemq::util::Queue< T > +activemq::io::BufferedInputStream +activemq::network::SocketInputStream +activemq::io::BufferedOutputStream +activemq::network::SocketOutputStream + +List of all members. + + + + + + + + + + + + + + +

Public Member Functions

virtual void lock ()=0 throw (exceptions::ActiveMQException)
virtual void unlock ()=0 throw (exceptions::ActiveMQException)
virtual void wait ()=0 throw (exceptions::ActiveMQException)
virtual void wait (unsigned long millisecs)=0 throw (exceptions::ActiveMQException)
virtual void notify ()=0 throw ( exceptions::ActiveMQException )
virtual void notifyAll ()=0 throw ( exceptions::ActiveMQException )
+

Detailed Description

+The interface for all synchronizable objects (that is, objects that can be locked and unlocked). +

+


Member Function Documentation

+ +
+
+ + + + + + + + +
virtual void activemq::concurrent::Synchronizable::lock (  )  throw (exceptions::ActiveMQException) [pure virtual]
+
+ +

+ +

+
+ + + + + + + + +
virtual void activemq::concurrent::Synchronizable::notify (  )  throw ( exceptions::ActiveMQException ) [pure virtual]
+
+ +

+ +

+
+ + + + + + + + +
virtual void activemq::concurrent::Synchronizable::notifyAll (  )  throw ( exceptions::ActiveMQException ) [pure virtual]
+
+ +

+ +

+
+ + + + + + + + +
virtual void activemq::concurrent::Synchronizable::unlock (  )  throw (exceptions::ActiveMQException) [pure virtual]
+
+ +

+ +

+
+ + + + + + + + + +
virtual void activemq::concurrent::Synchronizable::wait (unsigned long  millisecs  )  throw (exceptions::ActiveMQException) [pure virtual]
+
+
+ +

+Waits on a signal from this object, which is generated by a call to Notify. Must have this object locked before calling. This wait will timeout after the specified time interval.

Parameters:
+ + +
millisecs the time in millisecsonds to wait, or WAIT_INIFINITE
+
+
Exceptions:
+ + +
ActiveMQException 
+
+ +

+Implemented in activemq::concurrent::Mutex, activemq::io::BufferedInputStream, activemq::io::BufferedOutputStream, activemq::network::SocketInputStream, activemq::network::SocketOutputStream, activemq::transport::FutureResponse, activemq::util ::Queue< T >, activemq::util::Queue< std::pair< Runnable *, TaskListener * > >, and activemq::util::Queue< cms::Message * >. +

+

+ +

+
+ + + + + + + + +
virtual void activemq::concurrent::Synchronizable::wait (  )  throw (exceptions::ActiveMQException) [pure virtual]
+
+ +

+


The documentation for this class was generated from the following file:
    +
  • C:/Apps/main/activemq/concurrent/Synchronizable.h
+
Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.png URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.png?rev=428212&view=auto ============================================================================== Binary file - no diff available. Propchange: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_synchronizable.png ------------------------------------------------------------------------------ svn:mime-type = application/octet-stream Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread-members.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread-members.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread-members.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread-members.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,31 @@ + + +activemq-cpp: Member List + + + + + + +

activemq::concurrent::Thread Member List

This is the complete list of members for activemq::concurrent::Thread, including all inherited members.

+ + + + + + + +
getId(void)activemq::concurrent::Thread [static]
join()activemq::concurrent::Thread [virtual]
run()activemq::concurrent::Thread [inline, virtual]
sleep(int millisecs)activemq::concurrent::Thread [static]
start()activemq::concurrent::Thread [virtual]
Thread()activemq::concurrent::Thread
Thread(Runnable *task)activemq::concurrent::Thread


Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,214 @@ + + +activemq-cpp: activemq::concurrent::Thread Class Reference + + + + + + + +

activemq::concurrent::Thread Class Reference

#include <Thread.h> +

+

Inheritance diagram for activemq::concurrent::Thread: +

+ +activemq::concurrent::Runnable + +List of all members. + + + + + + + + + + + + + + + + + +

Public Member Functions

 Thread ()
 Thread (Runnable *task)
virtual void start () throw ( exceptions::ActiveMQException )
virtual void join () throw ( exceptions::ActiveMQException )
virtual void run ()

Static Public Member Functions

static void sleep (int millisecs)
static unsigned long getId (void)
+

Detailed Description

+Basic thread class - mimics the Java Thread. Derived classes may implement the run method, or this class can be used as is with a provided Runnable delegate. +

+


Constructor & Destructor Documentation

+ +
+
+ + + + + + + + +
Thread::Thread (  ) 
+
+
+ +

+default Constructor +

+

+ +

+
+ + + + + + + + + +
Thread::Thread (Runnable task  ) 
+
+
+ +

+Constructor

Parameters:
+ + +
task the Runnable that this thread manages
+
+ +
+

+


Member Function Documentation

+ +
+
+ + + + + + + + + +
unsigned long Thread::getId (void   )  [static]
+
+
+ +

+Obtains the Thread Id of the current thread

Returns:
Thread Id
+ +
+

+ +

+
+ + + + + + + + +
void Thread::join (  )  throw ( exceptions::ActiveMQException ) [virtual]
+
+
+ +

+Wait til the thread exits. This is when the run() method has returned or has thrown an exception. +

+

+ +

+
+ + + + + + + + + +
virtual void activemq::concurrent::Thread::run (void   )  [inline, virtual]
+
+
+ +

+Default implementation of the run method - does nothing. +

+Implements activemq::concurrent::Runnable. +

+

+ +

+
+ + + + + + + + + +
void Thread::sleep (int  millisecs  )  [static]
+
+
+ +

+Halts execution of the calling thread for a specified no of millisec.

+Note that this method is a static method that applies to the calling thread and not to the thread object.

Parameters:
+ + +
millisecs time in milliseconds to sleep
+
+ +
+

+ +

+
+ + + + + + + + +
void Thread::start (  )  throw ( exceptions::ActiveMQException ) [virtual]
+
+
+ +

+Creates a system thread and starts it in a joinable mode. Upon creation, the run() method of either this object or the provided Runnable object will be invoked in the context of this thread.

Exceptions:
+ + +
runtime_error is thrown if the system could not start the thread.
+
+ +
+

+


The documentation for this class was generated from the following files:
    +
  • C:/Apps/main/activemq/concurrent/Thread.h
  • C:/Apps/main/activemq/concurrent/Thread.cpp
+
Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.png URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.png?rev=428212&view=auto ============================================================================== Binary file - no diff available. Propchange: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread.png ------------------------------------------------------------------------------ svn:mime-type = application/octet-stream Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool-members.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool-members.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool-members.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool-members.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,38 @@ + + +activemq-cpp: Member List + + + + + + +

activemq::concurrent::ThreadPool Member List

This is the complete list of members for activemq::concurrent::ThreadPool, including all inherited members.

+ + + + + + + + + + + + + + +
deQueueTask(void)activemq::concurrent::ThreadPool [virtual]
getBacklog(void) const activemq::concurrent::ThreadPool [inline, virtual]
getBlockSize(void) const activemq::concurrent::ThreadPool [inline, virtual]
getFreeThreadCount(void) const activemq::concurrent::ThreadPool [inline, virtual]
getInstance(void)activemq::concurrent::ThreadPool [inline, static]
getMaxThreads(void) const activemq::concurrent::ThreadPool [inline, virtual]
getPoolSize(void) const activemq::concurrent::ThreadPool [inline, virtual]
onTaskCompleted(PooledThread *thread)activemq::concurrent::ThreadPool [virtual]
onTaskException(PooledThread *thread, exceptions::ActiveMQException &ex)activemq::concurrent::ThreadPool [virtual]
onTaskStarted(PooledThread *thread)activemq::concurrent::ThreadPool [virtual]
queueTask(Task task)activemq::concurrent::ThreadPool [virtual]
reserve(unsigned long size)activemq::concurrent::ThreadPool [virtual]
setBlockSize(unsigned long blockSize)activemq::concurrent::ThreadPool [virtual]
setMaxThreads(unsigned long maxThreads)activemq::concurrent::ThreadPool [virtual]


Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1concurrent_1_1_thread_pool.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,410 @@ + + +activemq-cpp: activemq::concurrent::ThreadPool Class Reference + + + + + + + +

activemq::concurrent::ThreadPool Class Reference

#include <ThreadPool.h> +

+List of all members. + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +

Public Member Functions

virtual void queueTask (Task task) throw ( exceptions::ActiveMQException )
virtual Task deQueueTask (void) throw ( exceptions::ActiveMQException )
virtual unsigned long getPoolSize (void) const
virtual unsigned long getBacklog (void) const
virtual void reserve (unsigned long size)
virtual unsigned long getMaxThreads (void) const
virtual void setMaxThreads (unsigned long maxThreads)
virtual unsigned long getBlockSize (void) const
virtual void setBlockSize (unsigned long blockSize)
virtual unsigned long getFreeThreadCount (void) const
virtual void onTaskStarted (PooledThread *thread)
virtual void onTaskCompleted (PooledThread *thread)
virtual void onTaskException (PooledThread *thread, exceptions::ActiveMQException &ex)

Static Public Member Functions

static ThreadPoolgetInstance (void)
+


Detailed Description

+Defines a Thread Pool object that implements the functionality of pooling threads to perform user tasks. The Thread Poll has max size that it will grow to. The thread pool allocates threads in blocks. When there are no waiting worker threads and a task is queued then a new batch is allocated. The user can specify the size of the blocks, otherwise a default value is used.

+When the user queues a task they must also queue a listner to be notified when the task has completed, this provides the user with a mechanism to know when a task object can be freed.

+To have the Thread Pool perform a task, the user enqueue's an object that implements the Runnable insterface and one of the worker threads will executing it in its thread context. +

+


Member Function Documentation

+ +
+
+ + + + + + + + + +
ThreadPool::Task ThreadPool::deQueueTask (void   )  throw ( exceptions::ActiveMQException ) [virtual]
+
+
+ +

+DeQueue a task to be completed by one of the Pooled Threads. A caller of this method will block until there is something in the tasks queue, therefore care must be taken when calling this function. Normally clients of ThreadPool don't use this, only the PooledThread objects owned by this ThreadPool.

Returns:
object that derives from Runnable
+
Exceptions:
+ + +
ActiveMQException 
+
+ +
+

+ +

+
+ + + + + + + + + +
virtual unsigned long activemq::concurrent::ThreadPool::getBacklog (void   )  const [inline, virtual]
+
+
+ +

+Returns the current backlog of items in the tasks queue, this is how much work is still waiting to get done.

Returns:
number of outstanding tasks.
+ +
+

+ +

+
+ + + + + + + + + +
virtual unsigned long activemq::concurrent::ThreadPool::getBlockSize (void   )  const [inline, virtual]
+
+
+ +

+Gets the Max number of threads that can be allocated at a time when new threads are needed.

Returns:
max Thread Block Size
+ +
+

+ +

+
+ + + + + + + + + +
virtual unsigned long activemq::concurrent::ThreadPool::getFreeThreadCount (void   )  const [inline, virtual]
+
+
+ +

+Returns the current number of available threads in the pool, threads that are performing a user task are considered unavailable. This value could change immeadiately after calling as Threads could finish right after and be available again. This is informational only.

Returns:
totoal free threads
+ +
+

+ +

+
+ + + + + + + + + +
static ThreadPool* activemq::concurrent::ThreadPool::getInstance (void   )  [inline, static]
+
+
+ +

+Return the one and only Thread Pool instance.

Returns:
The Thread Pool Pointer
+ +
+

+ +

+
+ + + + + + + + + +
virtual unsigned long activemq::concurrent::ThreadPool::getMaxThreads (void   )  const [inline, virtual]
+
+
+ +

+Get the Max Number of Threads this Pool can contain

Returns:
max size
+ +
+

+ +

+
+ + + + + + + + + +
virtual unsigned long activemq::concurrent::ThreadPool::getPoolSize (void   )  const [inline, virtual]
+
+
+ +

+Returns the current number of Threads in the Pool, this is how many there are now, not how many are active or the max number that might exist.

Returns:
integer number of threads in existance.
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::onTaskCompleted (PooledThread *  thread  )  [virtual]
+
+
+ +

+Called by a pooled thread when it has completed a task and is going back to waiting for another task to run, this will increment the free threads counter.

Parameters:
+ + +
thread Pointer the the Pooled Thread that is making this call.
+
+ +
+

+ +

+
+ + + + + + + + + + + + + + + + + + +
void ThreadPool::onTaskException (PooledThread *  thread,
exceptions::ActiveMQException &  ex 
) [virtual]
+
+
+ +

+Called by a pooled thread when it has encountered an exception while running a user task, after receiving this notification the callee should assume that the PooledThread is now no longer running.

Parameters:
+ + + +
thread Pointer to the Pooled Thread that is making this call
ex The Exception that occured.
+
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::onTaskStarted (PooledThread *  thread  )  [virtual]
+
+
+ +

+Called by a pooled thread when it is about to begin executing a new task. This will decrement the available threads counter so that this object knows when there are no more free threads and must create new ones.

Parameters:
+ + +
thread Pointer to the Pooled Thread that is making this call
+
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::queueTask (Task  task  )  throw ( exceptions::ActiveMQException ) [virtual]
+
+
+ +

+Queue a task to be completed by one of the Pooled Threads. tasks are serviced as soon as a PooledThread is available to run it.

Parameters:
+ + +
task object that derives from Runnable
+
+
Exceptions:
+ + +
ActiveMQException 
+
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::reserve (unsigned long  size  )  [virtual]
+
+
+ +

+Ensures that there is at least the specified number of Threads allocated to the pool. If the size is greater than the MAX number of threads in the pool, then only MAX threads are reservved. If the size is smaller than the number of threads currently in the pool, than nothing is done.

Parameters:
+ + +
size the number of threads to reserve.
+
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::setBlockSize (unsigned long  blockSize  )  [virtual]
+
+
+ +

+Sets the Max number of Threads that can be allocated at a time when the Thread Pool determines that more Threads are needed.

Parameters:
+ + +
blockSize Max Thread Block Size
+
+ +
+

+ +

+
+ + + + + + + + + +
void ThreadPool::setMaxThreads (unsigned long  maxThreads  )  [virtual]
+
+
+ +

+Sets the Max number of threads this pool can contian. if this value is smaller than the current size of the pool nothing is done.

Parameters:
+ + +
maxThreads total number of threads that can be pooled
+
+ +
+

+


The documentation for this class was generated from the following files:
    +
  • C:/Apps/main/activemq/concurrent/ThreadPool.h
  • C:/Apps/main/activemq/concurrent/ThreadPool.cpp
+
Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory-members.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory-members.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory-members.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory-members.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,25 @@ + + +activemq-cpp: Member List + + + + + + +

activemq::connector::ConnectorFactory Member List

This is the complete list of members for activemq::connector::ConnectorFactory, including all inherited members.

+ +
createConnector(const activemq::util::Properties &properties, activemq::transport::Transport *transport)=0activemq::connector::ConnectorFactory [pure virtual]


Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,74 @@ + + +activemq-cpp: activemq::connector::ConnectorFactory Class Reference + + + + + + + +

activemq::connector::ConnectorFactory Class Reference

#include <ConnectorFactory.h> +

+List of all members. + + + + +

Public Member Functions

virtual Connector * createConnector (const activemq::util::Properties &properties, activemq::transport::Transport *transport)=0
+


Detailed Description

+Interface class for all Connector Factory Classes +

+


Member Function Documentation

+ +
+
+ + + + + + + + + + + + + + + + + + +
virtual Connector* activemq::connector::ConnectorFactory::createConnector (const activemq::util::Properties properties,
activemq::transport::Transport transport 
) [pure virtual]
+
+
+ +

+Creates a connector

Parameters:
+ + + +
properties The Properties that the new connector is configured with
transport the Transport that the connector should use
+
+ +
+

+


The documentation for this class was generated from the following file:
    +
  • C:/Apps/main/activemq/connector/ConnectorFactory.h
+
Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map-members.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map-members.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map-members.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map-members.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,29 @@ + + +activemq-cpp: Member List + + + + + + +

activemq::connector::ConnectorFactoryMap Member List

This is the complete list of members for activemq::connector::ConnectorFactoryMap, including all inherited members.

+ + + + + +
getFactoryNames(std::vector< std::string > &factoryList)activemq::connector::ConnectorFactoryMap
getInstance(void)activemq::connector::ConnectorFactoryMap [static]
lookup(const std::string &name)activemq::connector::ConnectorFactoryMap
registerConnectorFactory(const std::string &name, ConnectorFactory *factory)activemq::connector::ConnectorFactoryMap
unregisterConnectorFactory(const std::string &name)activemq::connector::ConnectorFactoryMap


Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ + Added: incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map.html URL: http://svn.apache.org/viewvc/incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map.html?rev=428212&view=auto ============================================================================== --- incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map.html (added) +++ incubator/activemq/site/cms/html/classactivemq_1_1connector_1_1_connector_factory_map.html Wed Aug 2 19:24:43 2006 @@ -0,0 +1,180 @@ + + +activemq-cpp: activemq::connector::ConnectorFactoryMap Class Reference + + + + + + + +

activemq::connector::ConnectorFactoryMap Class Reference

#include <ConnectorFactoryMap.h> +

+List of all members. + + + + + + + + + + + + + +

Public Member Functions

void registerConnectorFactory (const std::string &name, ConnectorFactory *factory)
void unregisterConnectorFactory (const std::string &name)
ConnectorFactorylookup (const std::string &name)
std::size_t getFactoryNames (std::vector< std::string > &factoryList)

Static Public Member Functions

static ConnectorFactoryMapgetInstance (void)
+


Detailed Description

+Lookup Map for Connector Factories. Use the Connector name to find the associated factory. This class does not take ownership of the stored factories, they must be deallocated somewhere. +

+


Member Function Documentation

+ +
+
+ + + + + + + + + +
std::size_t ConnectorFactoryMap::getFactoryNames (std::vector< std::string > &  factoryList  ) 
+
+
+ +

+Fetch a list of factory names that this Map contains

Parameters:
+ + +
factoryList vector object to receive the list
+
+
Returns:
count of factories.
+ +
+

+ +

+
+ + + + + + + + + +
ConnectorFactoryMap * ConnectorFactoryMap::getInstance (void   )  [static]
+
+
+ +

+Gets a singleton instance of this class. +

+

+ +

+
+ + + + + + + + + +
ConnectorFactory * ConnectorFactoryMap::lookup (const std::string &  name  ) 
+
+
+ +

+Lookup the named factory in the Map

Parameters:
+ + +
name the factory name to lookup
+
+
Returns:
the factory assciated with the name, or NULL
+ +
+

+ +

+
+ + + + + + + + + + + + + + + + + + +
void ConnectorFactoryMap::registerConnectorFactory (const std::string &  name,
ConnectorFactory factory 
)
+
+
+ +

+Registers a new Connector Factory with this map

Parameters:
+ + + +
name to associate the factory with
factory to store.
+
+ +
+

+ +

+
+ + + + + + + + + +
void ConnectorFactoryMap::unregisterConnectorFactory (const std::string &  name  ) 
+
+
+ +

+Unregisters a Connector Factory with this map

Parameters:
+ + +
name of the factory to remove
+
+ +
+

+


The documentation for this class was generated from the following files:
    +
  • C:/Apps/main/activemq/connector/ConnectorFactoryMap.h
  • C:/Apps/main/activemq/connector/ConnectorFactoryMap.cpp
+
Generated on Tue Aug 1 09:18:13 2006 for activemq-cpp by  + +doxygen 1.4.7
+ +