Class List

Here are the classes, structs, unions and interfaces with brief descriptions:
qpid::sys::AbsTimeClass to represent an instant in time: The time resolution is in nanosecs, and this is held with 64 bits giving a total time span from about 25 million years ago to 25 million years hence
qpid::framing::AccumulatedAckKeeps an accumulated record of acknowledged messages (by delivery tag)
qpid::client::AckPolicyPolicy for automatic acknowledgement of messages
qpid::AddressAddress is a variant of all address types, more coming in future
qpid::framing::AddressVisitor< R >Convert the address of variant value to type R
qpid::framing::AMQCommandControlBody< T >AMQBody wrapper for Command and Control
qpid::framing::ApplyVisitor< V >Apply a visitor to the nested variant
qpid::sys::APRBaseUse of APR libraries necessitates explicit init and terminate calls
qpid::sys::APRPoolSingleton APR memory pool
qpid::amqp_0_10::ArrayDomain< UnknownType >A non-domain array is represented as and array of UnknownType
qpid::client::AsyncSession_0_10AMQP 0-10 session API with keyword arguments
qpid::client::no_keyword::AsyncSession_0_10AMQP 0-10 asynchronous session API
qpid::sys::AtomicCountAtomic counter
qpid::sys::AtomicValue< T >Atomic value of type T
qpid::client::AutoCancelAutoCancel cancels a subscription in its destructor
qpid::sys::AutoShlibA shared library handle that unloads the shlib in it's dtor
qpid::amqp_0_10::BitBit is a presence indicator - an optional value with no encoding
qpid::framing::Blob< Size, BaseType >A Blob is a chunk of memory which can contain a single object at a time-arbitrary type, provided sizeof(T)<=blob.size()
qpid::sys::BlockingQueue< T >A simple blocking queue template
qpid::amqp_0_10::BodyHolds data from a body frame
qpid::framing::BodyHandlerInterface to handle incoming frame bodies
qpid::framing::BodyHolderHolder for arbitrary frame body
qpid::broker::BrokerA broker instance
qpid::broker::BrokerSingletonBrokerSingleton is a smart pointer to a process-wide singleton broker started on an os-chosen port
qpid::framing::Buffer::IteratorBuffer input/output iterator
qpid::framing::ChannelHandlerSets the channel number on outgoing frames
qpid::cluster::ClusterConnection to the cluster
qpid::cluster::ClusterMapMap of established cluster members and newbies waiting for a brain dump
qpid::amqp_0_10::CodecAMQP 0-10 encoding and decoding
qpid::amqp_0_10::Codec::Encoder< OutIter >Encode to an output byte iterator
qpid::framing::CommandInvalidExceptionThe command segments could not be decoded
qpid::amqp_0_10::CommandInvalidExceptionThe command segments could not be decoded
qpid::amqp_0_10::CommmandPacker< T >Packer for commands - serialize session.header before pack bits
qpid::CommonOptionsStandard options for configuration
qpid::client::CompletionAsynchronous commands that do not return a result will return a Completion
qpid::sys::ConditionA condition variable for thread synchronization
qpid::client::ConnectionRepresents a connection to an AMQP broker
qpid::cluster::ConnectionIntercept broker::Connection calls for shadow and local cluster connections
qpid::sys::ConnectionCodecInterface of coder/decoder for a connection of a specific protocol version
qpid::cluster::ConnectionCodecEncapsulates the standard amqp_0_10::ConnectionCodec and sets up a cluster::Connection for the connection
qpid::amqp_0_10::ConnectionExceptionRaised when the connection is unexpectedly closed
qpid::framing::ConnectionForcedExceptionAn operator intervened to close the connection for some reason
qpid::amqp_0_10::ConnectionForcedExceptionAn operator intervened to close the connection for some reason
qpid::sys::ConnectionInputHandlerFactoryCallback interface used by the Acceptor to create a ConnectionInputHandler for each new connection
qpid::sys::ConnectionOutputHandlerProvides the output handler associated with a connection
qpid::sys::ConnectionOutputHandlerPtrA ConnectionOutputHandler that delegates to another ConnectionOutputHandler
qpid::client::ConnectionSettingsSettings for a Connection
qpid::broker::ConnectionTokenAn empty interface allowing opaque implementations of some form of token to identify a connection
qpid::framing::ConvertVisitor< R >Convert the variant value to type R
qpid::sys::CopyOnWriteArray< T >An array that copies on adding/removing element allowing lock-free iteration
qpid::cluster::CpgLightweight C++ interface to cpg.h operations
qpid::broker::DaemonTools for forking and managing a daemon process
qpid::DataDirDataDir class
qpid::DecoderBase< Derived >Base class for decoders, provides generic decode functions
qpid::sys::DeletionManager< H >DeletionManager keeps track of handles that need to be deleted but may still be in use by one of the threads concurrently
qpid::broker::DeliveryAdapterThe intention behind this interface is to separate the generic handling of some form of message delivery to clients that is contained in the version independent Channel class from the details required for a particular situation or version
qpid::broker::DeliveryRecordRecord of a delivery for which an ack is outstanding
qpid::broker::DeliveryTokenA DeliveryToken allows the delivery of a message to be associated with whatever mechanism caused it to be delivered
qpid::cluster::DispatchableInterface for classes that have some "events" that need dispatching in a thread
qpid::sys::DispatchHandleIn order to have your own handle (file descriptor on Unix) watched by the poller you need to:
qpid::broker::DtxWorkRecordRepresents the work done under a particular distributed transaction across potentially multiple channels
qpid::cluster::DumpClientA client that dumps the contents of a local broker to a remote one using AMQP
qpid::sys::DurationClass to represent the duration between instants of time: As AbsTime this class also uses nanosecs for its time resolution
qpid::EncoderBase< Derived >Base class for encoders, provides generic encode functions
qpid::ErrnoExceptionException that includes an errno message
qpid::cluster::EventEvents are sent to/received from the cluster
qpid::ExceptionBase class for Qpid runtime exceptions
qpid::sys::ExceptionHolderHolder for exceptions
qpid::broker::ExternalQueueStoreEmpty class to be used by any module that wanted to set an external per queue store into persistableQueue
qpid::cluster::FailoverExchangeFailover exchange provides failover host list, as specified in AMQP 0-10
qpid::framing::FieldTableA set of name-value pairs
qpid::framing::FieldValueValue that can appear in an AMQP field table
qpid::framing::FieldValueExceptionException that is the base exception for all field table errors
qpid::sys::FileSysDirRepresents a filesystem directory accessible from the local host
qpid::client::FlowControlFlow control works by associating a finite amount of "credit" associated with a subscription
qpid::sys::ForkFork the process
qpid::sys::ForkWithMessageLike Fork but also allows the child to send a string message or throw an exception to the parent
qpid::framing::FrameDecoderDecode a frame from buffer
qpid::framing::FrameDefaultVisitorVisitor for all concrete frame body types, which combines AMQBodyConstVisitor and MethodBodyDefaultVisitor
qpid::framing::FrameSetCollects the frames representing a message
qpid::framing::FramingErrorExceptionA valid frame header cannot be formed from the incoming byte stream
qpid::amqp_0_10::FramingErrorExceptionA valid frame header cannot be formed from the incoming byte stream
qpid::framing::Handler< T >::Functor< F >Adapt any void(T) functor as a Handler
qpid::framing::Handler< T >::InOutHandlerSupport for implementing an in-out handler pair as a single class
qpid::framing::Handler< T >::InOutHandlerInterfaceInterface for a handler that implements a pair of in/out handle operations
qpid::framing::Handler< T >::MemFunRef< X, F >Adapt a member function of X as a Handler
qpid::broker::HandlerImplBase template for protocol handler implementations
qpid::framing::IllegalArgumentExceptionThe command argument is malformed, i.e
qpid::amqp_0_10::IllegalArgumentExceptionThe command argument is malformed, i.e
qpid::framing::IllegalStateExceptionThe peer sent a command that is not permitted in the current state of the session
qpid::amqp_0_10::IllegalStateExceptionThe peer sent a command that is not permitted in the current state of the session
qpid::InlineAllocator< BaseAllocator, Max >An allocator that has inline storage for up to Max objects of type BaseAllocator::value_type
qpid::InlineVector< T, Max, Alloc >A vector that stores up to Max elements in inline storage, otherwise uses normal vector allocation
qpid::framing::InternalErrorExceptionThe peer could not complete the command because of an internal error
qpid::amqp_0_10::InternalErrorExceptionThe peer could not complete the command because of an internal error
qpid::framing::InvalidArgumentExceptionAn invalid argument was passed to a command, and the operation could not proceed
qpid::amqp_0_10::InvalidArgumentExceptionAn invalid argument was passed to a command, and the operation could not proceed
qpid::framing::InvalidConversionExceptionException thrown when we can't perform requested conversion
qpid::framing::InvalidPathExceptionThe client tried to work with an unknown virtual host
qpid::amqp_0_10::InvalidPathExceptionThe client tried to work with an unknown virtual host
qpid::framing::InvokerBase class for invoker visitors
qpid::client::LocalQueueA local queue to collect messages retrieved from a remote broker queue
qpid::sys::LockFileLockFile represents a locked file suitable for a coarse-grain system lock
qpid::sys::LockPtr< T, Lock >LockPtr is a smart pointer to T
qpid::log::LoggerCentral logging agent
qpid::log::Logger::OutputLogging output sink
qpid::cluster::MemberIdFirst=node-id, second=pid
qpid::client::MessageA message sent to or received from the broker
qpid::broker::MessageDeliveryTODO: clean this up; we don't need it anymore in its current form
qpid::client::MessageListenerImplement a subclass of MessageListener and subscribe it using the SubscriptionManager to receive messages
qpid::broker::MessageStoreAn abstraction of the persistent storage for messages
qpid::broker::MessageStoreModuleA null implementation of the MessageStore interface
qpid::sys::MonitorA monitor is a condition variable and a mutex
qpid::MsgA simple wrapper for std::ostringstream that allows in place construction of a message and automatic conversion to string
qpid::sys::MutexMutex lock
qpid::framing::NoBlankVisitor< R >Boost::static_visitor that throws an exception if variant contains a blank
qpid::cluster::NoOpConnectionOutputHandlerOutput handler for frames sent to noop connections
qpid::amqp_0_10::NormalDetachedExceptionThe session was detached by request
qpid::amqp_0_10::NormalExceptionThe connection closed normally
qpid::amqp_0_10::NormalExpiredExceptionThe session was detached by request
qpid::framing::NotAllowedExceptionThe peer tried to use a command a manner that is inconsistent with the rules described in the specification
qpid::amqp_0_10::NotAllowedExceptionThe peer tried to use a command a manner that is inconsistent with the rules described in the specification
qpid::amqp_0_10::NotAttachedDetachedExceptionThe transport is not currently attached to any session
qpid::framing::NotAttachedExceptionThe transport is not currently attached to any session
qpid::amqp_0_10::NotAttachedExpiredExceptionThe transport is not currently attached to any session
qpid::framing::NotFoundExceptionThe client attempted to work with a server entity that does not exist
qpid::amqp_0_10::NotFoundExceptionThe client attempted to work with a server entity that does not exist
qpid::framing::NotImplementedExceptionThe peer tried to use functionality that is not implemented in its partner
qpid::amqp_0_10::NotImplementedExceptionThe peer tried to use functionality that is not implemented in its partner
qpid::broker::NullMessageStoreA null implementation of the MessageStore interface
qpid::log::OptionsLogging options for config parser
qpid::OptionsBase class for options
qpid::log::OstreamOutputOstreamOutput is a reusable logging sink that directs logging to a C++ ostream
qpid::cluster::OutputInterceptorInterceptor for connection OutputHandler, manages outgoing message replication
qpid::amqp_0_10::PackBits"Encoder" that encodes a struct as a set of bit flags for all non-empty members
qpid::amqp_0_10::PackedDecoder< Decoder, Bits >Decode members enabled by Bits
qpid::amqp_0_10::Packer< T >Helper to serialize packed structs
qpid::broker::PersistableBase class for all persistable objects
qpid::broker::PersistableConfigThe interface used by general-purpose persistable configuration for the message store
qpid::broker::PersistableExchangeThe interface exchanges must expose to the MessageStore in order to be persistable
qpid::broker::PersistableMessageBase class for persistable messages
qpid::broker::PersistableQueueThe interface queues must expose to the MessageStore in order to be persistable
qpid::PluginPlug-in base class
qpid::Plugin::TargetBase interface for targets that can receive plug-ins
qpid::sys::PODMutexPODMutex is a POD, can be static-initialized with PODMutex m = QPID_PODMUTEX_INITIALIZER
qpid::sys::PollableConditionA pollable condition to integrate in-process conditions with IO conditions in a polling loop
qpid::sys::PollableQueue< T >A queue that can be polled by sys::Poller
qpid::framing::PreconditionFailedExceptionThe client requested a command that was not allowed because some precondition failed
qpid::amqp_0_10::PreconditionFailedExceptionThe client requested a command that was not allowed because some precondition failed
qpid::framing::ProxyBase class for proxies
qpid::cluster::ProxyInputHandlerProxies ConnectionInputHandler functions and ensures target.closed() is called, on deletion if not before
qpid::broker::QueueThe brokers representation of an amqp queue
qpid::broker::QueueCleanerTimerTask to purge expired messages from queues
qpid::client::QueueOptionsA help class to set options on the Queue
qpid::broker::QueueRegistryA registry of queues indexed by queue name
qpid::Range< T >A range of values, used in RangeSet
qpid::RangeSet< T >A set implemented as a list of [begin, end) ranges
qpid::broker::RateTrackerSimple rate tracker: represents some value that can be incremented, then can periodcially sample the rate of increments
qpid::broker::RecoverableConfigThe interface through which configurations are recovered
qpid::broker::RecoverableExchangeThe interface through which bindings are recovered
qpid::broker::RecoverableMessageThe interface through which messages are reloaded on recovery
qpid::broker::RecoverableQueueThe interface through which messages are added back to queues on recovery
qpid::broker::RecoverableTransactionThe interface through which prepared 2pc transactions are recovered
qpid::RefCountedReference-counted base class
qpid::RefCountedBufferReference-counted byte buffer
qpid::RefCountedBuffer::pointerSmart char pointer to a reference counted buffer
qpid::framing::RelaySends to the specified handler a copy of the frame it is applied to
qpid::framing::ResourceDeletedExceptionA server entity the client is working with has been deleted
qpid::amqp_0_10::ResourceDeletedExceptionA server entity the client is working with has been deleted
qpid::framing::ResourceLimitExceededExceptionThe client exceeded its resource allocation
qpid::amqp_0_10::ResourceLimitExceededExceptionThe client exceeded its resource allocation
qpid::amqp_0_10::ResourceLockedExceptionThe client attempted to work with a server entity to which it has no access because another client is working with it
qpid::framing::ResourceLockedExceptionThe client attempted to work with a server entity to which it has no access because another client is working with it
qpid::sys::RunnableInterface for objects that can be run, e.g
qpid::sys::RWlockRW lock
qpid::sys::ScopedDecrement< T >Decrement counter in constructor and increment in destructor
qpid::sys::ScopedIncrement< T, F >Increment counter in constructor and decrement in destructor
qpid::sys::ScopedLock< L >Scoped lock template: calls lock() in ctor, unlock() in dtor
qpid::log::SelectorA selector identifies the set of log messages to enable
qpid::broker::SemanticStateSemanticState holds the L3 and L4 state of an open session, whether attached to a channel or suspended
qpid::framing::SendContentFunctor that sends frame to handler, refragmenting if necessary
qpid::framing::SequenceNumber4-byte sequence number that 'wraps around'
qpid::amqp_0_10::SerializableOptional< T >Serialization for optional values
qpid::SerializablePair< T, U >Serialize std::pair
qpid::amqp_0_10::SerializableString< T, SizeType, Unique >Template for length-prefixed strings/arrays
qpid::SerializeAs< Type, AsType >Serialize a type by converting it to/from another type
qpid::Serializer< Derived >Base class for all serializers
qpid::Serializer< Derived >::Ref< S >Wrapper functor to pass serializer functors by reference
qpid::Serializer< Derived >::ScopedLimitTemporarily set a lower relative limit on the serializer
qpid::client::no_keyword::Session_0_10AMQP 0-10 synchronous session API
qpid::client::Session_0_10AMQP 0-10 session API with keyword arguments
qpid::amqp_0_10::SessionAbortedExceptionRaised when a session is destroyed due to an execution.exception
qpid::broker::SessionAdapterPer-channel protocol adapter
qpid::client::SessionBase_0_10Base class for handles to an AMQP session
qpid::amqp_0_10::SessionBusyDetachedExceptionThe session is currently attached to another transport
qpid::framing::SessionBusyExceptionThe session is currently attached to another transport
qpid::amqp_0_10::SessionBusyExpiredExceptionThe session is currently attached to another transport
qpid::amqp_0_10::SessionDestroyedExceptionRaised when the state of a session has been destroyed
qpid::amqp_0_10::SessionDetachedExceptionRaised when a session with non-0 timeout is unexpectedly detached or if an attempt is made to use a session that is not attached
qpid::amqp_0_10::SessionExceptionRaised when a session is unexpectedly detached for any reason, or if an attempt is made to use a session that is not attached
qpid::amqp_0_10::SessionExpiredExceptionRaised when a session with 0 timeout is unexpectedly detached and therefore expires and is destroyed
qpid::amqp_0_10::SessionHandlerBase SessionHandler with logic common to both client and broker
qpid::broker::SessionHandlerA SessionHandler is associated with each active channel
qpid::SessionIdIdentifier for a session
qpid::broker::SessionManagerCreate and manage SessionState objects
qpid::SessionPointA point in the session
qpid::broker::SessionStateBroker-side session state includes session's handler chains, which may themselves have state
qpid::SessionStateSupport for session idempotence barrier and resume as defined in AMQP 0-10
qpid::SharedObject< T >Template to enforce shared object conventions
qpid::sys::ShlibEncapsulates a shared library handle
qpid::broker::SignalHandlerHandle signals e.g
qpid::log::SinkOptionsLogging sink options
qpid::log::StatementPOD struct representing a logging statement in source code
qpid::sys::StateMonitor< Enum, MaxEnum >A monitor with an enum state value
qpid::client::SubscriptionManagerA class to help create and manage subscriptions
qpid::log::posix::SyslogFacilityProvides a type that can be passed to << and >> operators to convert syslog facility values to/from strings
qpid::TcpAddressTCP address of a broker - host:port
qpid::broker::TokensA vector of string tokens
qpid::broker::TopicPatternTokens that have been normalized as a pattern and can be matched with topic Tokens
qpid::framing::TransferContentMessage content
qpid::amqp_0_10::TransportBusyDetachedExceptionThe transport is currently attached to another session
qpid::framing::TransportBusyExceptionThe transport is currently attached to another session
qpid::amqp_0_10::TransportBusyExpiredExceptionThe transport is currently attached to another session
qpid::broker::TxAcceptDefines the transactional behaviour for accepts received by a transactional channel
qpid::broker::TxPublishDefines the behaviour for publish operations on a transactional channel
qpid::framing::typed_in_place_factory0< T >0-arg typed_in_place_factory, missing in pre-1.35 boost
qpid::client::TypedResult< T >Returned by asynchronous commands that return a result
qpid::framing::TypeFilter< Type >Predicate that selects frames by type
qpid::framing::UnauthorizedAccessExceptionThe client attempted to work with a server entity to which it has no access due to security settings
qpid::amqp_0_10::UnauthorizedAccessExceptionThe client attempted to work with a server entity to which it has no access due to security settings
qpid::amqp_0_10::UnitA Unit contains a frame header and associated value
qpid::amqp_0_10::UnknownIdsDetachedExceptionCommand data was received prior to any use of the command-point control
qpid::framing::UnknownIdsExceptionCommand data was received prior to any use of the command-point control
qpid::amqp_0_10::UnknownIdsExpiredExceptionCommand data was received prior to any use of the command-point control
qpid::amqp_0_10::UnknownTypeEncode/decode an unknown type based on typecode
qpid::UrlAn AMQP URL contains a list of addresses
qpid::framing::UuidA UUID is represented as a boost::array of 16 bytes
qpid::framing::Visit< T, R >Visit() interface for type T (optional return type R, default is void
qpid::framing::Visitable< T, Base >The base class for concrete visitable classes
qpid::framing::VisitableRoot< V, R >The root class for the hierarchy of objects visitable by Visitor V
qpid::amqp_0_10::VoidVoid type
qpid::sys::WaitableA monitor that keeps track of waiting threads
qpid::sys::Waitable::ScopedWaitUse this inside a scoped lock around the call to wait() to be counted as a waiter
qpid::amqp_0_10::Wrapper< T, Unique >Wrapper that behaves like type T but is a distinct type for overloading purposes
qpid::cluster::WriteEstimateEstimate the amount of data that a connection can write between sending a doOutput notice and re-receiving it

Generated on Thu Oct 16 13:37:44 2008 for Qpid by  doxygen 1.5.6