qpid::sys::AbsTime | Class 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::AccumulatedAck | Keeps an accumulated record of acknowledged messages (by delivery tag) |
qpid::client::AckPolicy | Policy for automatic acknowledgement of messages |
qpid::Address | Address 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::APRBase | Use of APR libraries necessitates explicit init and terminate calls |
qpid::sys::APRPool | Singleton APR memory pool |
qpid::amqp_0_10::ArrayDomain< UnknownType > | A non-domain array is represented as and array of UnknownType |
qpid::client::AsyncSession_0_10 | AMQP 0-10 session API with keyword arguments |
qpid::client::no_keyword::AsyncSession_0_10 | AMQP 0-10 asynchronous session API |
qpid::sys::AtomicCount | Atomic counter |
qpid::sys::AtomicValue< T > | Atomic value of type T |
qpid::client::AutoCancel | AutoCancel cancels a subscription in its destructor |
qpid::sys::AutoShlib | A shared library handle that unloads the shlib in it's dtor |
qpid::amqp_0_10::Bit | Bit 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::Body | Holds data from a body frame |
qpid::framing::BodyHandler | Interface to handle incoming frame bodies |
qpid::framing::BodyHolder | Holder for arbitrary frame body |
qpid::broker::Broker | A broker instance |
qpid::broker::BrokerSingleton | BrokerSingleton is a smart pointer to a process-wide singleton broker started on an os-chosen port |
qpid::framing::Buffer::Iterator | Buffer input/output iterator |
qpid::framing::ChannelHandler | Sets the channel number on outgoing frames |
qpid::cluster::Cluster | Connection to the cluster |
qpid::cluster::ClusterMap | Map of established cluster members and newbies waiting for a brain dump |
qpid::amqp_0_10::Codec | AMQP 0-10 encoding and decoding |
qpid::amqp_0_10::Codec::Encoder< OutIter > | Encode to an output byte iterator |
qpid::framing::CommandInvalidException | The command segments could not be decoded |
qpid::amqp_0_10::CommandInvalidException | The command segments could not be decoded |
qpid::amqp_0_10::CommmandPacker< T > | Packer for commands - serialize session.header before pack bits |
qpid::CommonOptions | Standard options for configuration |
qpid::client::Completion | Asynchronous commands that do not return a result will return a Completion |
qpid::sys::Condition | A condition variable for thread synchronization |
qpid::client::Connection | Represents a connection to an AMQP broker |
qpid::cluster::Connection | Intercept broker::Connection calls for shadow and local cluster connections |
qpid::sys::ConnectionCodec | Interface of coder/decoder for a connection of a specific protocol version |
qpid::cluster::ConnectionCodec | Encapsulates the standard amqp_0_10::ConnectionCodec and sets up a cluster::Connection for the connection |
qpid::amqp_0_10::ConnectionException | Raised when the connection is unexpectedly closed |
qpid::framing::ConnectionForcedException | An operator intervened to close the connection for some reason |
qpid::amqp_0_10::ConnectionForcedException | An operator intervened to close the connection for some reason |
qpid::sys::ConnectionInputHandlerFactory | Callback interface used by the Acceptor to create a ConnectionInputHandler for each new connection |
qpid::sys::ConnectionOutputHandler | Provides the output handler associated with a connection |
qpid::sys::ConnectionOutputHandlerPtr | A ConnectionOutputHandler that delegates to another ConnectionOutputHandler |
qpid::client::ConnectionSettings | Settings for a Connection |
qpid::broker::ConnectionToken | An 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::Cpg | Lightweight C++ interface to cpg.h operations |
qpid::broker::Daemon | Tools for forking and managing a daemon process |
qpid::DataDir | DataDir 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::DeliveryAdapter | The 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::DeliveryRecord | Record of a delivery for which an ack is outstanding |
qpid::broker::DeliveryToken | A DeliveryToken allows the delivery of a message to be associated with whatever mechanism caused it to be delivered |
qpid::cluster::Dispatchable | Interface for classes that have some "events" that need dispatching in a thread |
qpid::sys::DispatchHandle | In order to have your own handle (file descriptor on Unix) watched by the poller you need to: |
qpid::broker::DtxWorkRecord | Represents the work done under a particular distributed transaction across potentially multiple channels |
qpid::cluster::DumpClient | A client that dumps the contents of a local broker to a remote one using AMQP |
qpid::sys::Duration | Class 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::ErrnoException | Exception that includes an errno message |
qpid::cluster::Event | Events are sent to/received from the cluster |
qpid::Exception | Base class for Qpid runtime exceptions |
qpid::sys::ExceptionHolder | Holder for exceptions |
qpid::broker::ExternalQueueStore | Empty class to be used by any module that wanted to set an external per queue store into persistableQueue |
qpid::cluster::FailoverExchange | Failover exchange provides failover host list, as specified in AMQP 0-10 |
qpid::framing::FieldTable | A set of name-value pairs |
qpid::framing::FieldValue | Value that can appear in an AMQP field table |
qpid::framing::FieldValueException | Exception that is the base exception for all field table errors |
qpid::sys::FileSysDir | Represents a filesystem directory accessible from the local host |
qpid::client::FlowControl | Flow control works by associating a finite amount of "credit" associated with a subscription |
qpid::sys::Fork | Fork the process |
qpid::sys::ForkWithMessage | Like Fork but also allows the child to send a string message or throw an exception to the parent |
qpid::framing::FrameDecoder | Decode a frame from buffer |
qpid::framing::FrameDefaultVisitor | Visitor for all concrete frame body types, which combines AMQBodyConstVisitor and MethodBodyDefaultVisitor |
qpid::framing::FrameSet | Collects the frames representing a message |
qpid::framing::FramingErrorException | A valid frame header cannot be formed from the incoming byte stream |
qpid::amqp_0_10::FramingErrorException | A 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 >::InOutHandler | Support for implementing an in-out handler pair as a single class |
qpid::framing::Handler< T >::InOutHandlerInterface | Interface 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::HandlerImpl | Base template for protocol handler implementations |
qpid::framing::IllegalArgumentException | The command argument is malformed, i.e |
qpid::amqp_0_10::IllegalArgumentException | The command argument is malformed, i.e |
qpid::framing::IllegalStateException | The peer sent a command that is not permitted in the current state of the session |
qpid::amqp_0_10::IllegalStateException | The 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::InternalErrorException | The peer could not complete the command because of an internal error |
qpid::amqp_0_10::InternalErrorException | The peer could not complete the command because of an internal error |
qpid::framing::InvalidArgumentException | An invalid argument was passed to a command, and the operation could not proceed |
qpid::amqp_0_10::InvalidArgumentException | An invalid argument was passed to a command, and the operation could not proceed |
qpid::framing::InvalidConversionException | Exception thrown when we can't perform requested conversion |
qpid::framing::InvalidPathException | The client tried to work with an unknown virtual host |
qpid::amqp_0_10::InvalidPathException | The client tried to work with an unknown virtual host |
qpid::framing::Invoker | Base class for invoker visitors |
qpid::client::LocalQueue | A local queue to collect messages retrieved from a remote broker queue |
qpid::sys::LockFile | LockFile 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::Logger | Central logging agent |
qpid::log::Logger::Output | Logging output sink |
qpid::cluster::MemberId | First=node-id, second=pid |
qpid::client::Message | A message sent to or received from the broker |
qpid::broker::MessageDelivery | TODO: clean this up; we don't need it anymore in its current form |
qpid::client::MessageListener | Implement a subclass of MessageListener and subscribe it using the SubscriptionManager to receive messages |
qpid::broker::MessageStore | An abstraction of the persistent storage for messages |
qpid::broker::MessageStoreModule | A null implementation of the MessageStore interface |
qpid::sys::Monitor | A monitor is a condition variable and a mutex |
qpid::Msg | A simple wrapper for std::ostringstream that allows in place construction of a message and automatic conversion to string |
qpid::sys::Mutex | Mutex lock |
qpid::framing::NoBlankVisitor< R > | Boost::static_visitor that throws an exception if variant contains a blank |
qpid::cluster::NoOpConnectionOutputHandler | Output handler for frames sent to noop connections |
qpid::amqp_0_10::NormalDetachedException | The session was detached by request |
qpid::amqp_0_10::NormalException | The connection closed normally |
qpid::amqp_0_10::NormalExpiredException | The session was detached by request |
qpid::framing::NotAllowedException | The peer tried to use a command a manner that is inconsistent with the rules described in the specification |
qpid::amqp_0_10::NotAllowedException | The peer tried to use a command a manner that is inconsistent with the rules described in the specification |
qpid::amqp_0_10::NotAttachedDetachedException | The transport is not currently attached to any session |
qpid::framing::NotAttachedException | The transport is not currently attached to any session |
qpid::amqp_0_10::NotAttachedExpiredException | The transport is not currently attached to any session |
qpid::framing::NotFoundException | The client attempted to work with a server entity that does not exist |
qpid::amqp_0_10::NotFoundException | The client attempted to work with a server entity that does not exist |
qpid::framing::NotImplementedException | The peer tried to use functionality that is not implemented in its partner |
qpid::amqp_0_10::NotImplementedException | The peer tried to use functionality that is not implemented in its partner |
qpid::broker::NullMessageStore | A null implementation of the MessageStore interface |
qpid::log::Options | Logging options for config parser |
qpid::Options | Base class for options |
qpid::log::OstreamOutput | OstreamOutput is a reusable logging sink that directs logging to a C++ ostream |
qpid::cluster::OutputInterceptor | Interceptor 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::Persistable | Base class for all persistable objects |
qpid::broker::PersistableConfig | The interface used by general-purpose persistable configuration for the message store |
qpid::broker::PersistableExchange | The interface exchanges must expose to the MessageStore in order to be persistable |
qpid::broker::PersistableMessage | Base class for persistable messages |
qpid::broker::PersistableQueue | The interface queues must expose to the MessageStore in order to be persistable |
qpid::Plugin | Plug-in base class |
qpid::Plugin::Target | Base interface for targets that can receive plug-ins |
qpid::sys::PODMutex | PODMutex is a POD, can be static-initialized with PODMutex m = QPID_PODMUTEX_INITIALIZER |
qpid::sys::PollableCondition | A 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::PreconditionFailedException | The client requested a command that was not allowed because some precondition failed |
qpid::amqp_0_10::PreconditionFailedException | The client requested a command that was not allowed because some precondition failed |
qpid::framing::Proxy | Base class for proxies |
qpid::cluster::ProxyInputHandler | Proxies ConnectionInputHandler functions and ensures target.closed() is called, on deletion if not before |
qpid::broker::Queue | The brokers representation of an amqp queue |
qpid::broker::QueueCleaner | TimerTask to purge expired messages from queues |
qpid::client::QueueOptions | A help class to set options on the Queue |
qpid::broker::QueueRegistry | A 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::RateTracker | Simple rate tracker: represents some value that can be incremented, then can periodcially sample the rate of increments |
qpid::broker::RecoverableConfig | The interface through which configurations are recovered |
qpid::broker::RecoverableExchange | The interface through which bindings are recovered |
qpid::broker::RecoverableMessage | The interface through which messages are reloaded on recovery |
qpid::broker::RecoverableQueue | The interface through which messages are added back to queues on recovery |
qpid::broker::RecoverableTransaction | The interface through which prepared 2pc transactions are recovered |
qpid::RefCounted | Reference-counted base class |
qpid::RefCountedBuffer | Reference-counted byte buffer |
qpid::RefCountedBuffer::pointer | Smart char pointer to a reference counted buffer |
qpid::framing::Relay | Sends to the specified handler a copy of the frame it is applied to |
qpid::framing::ResourceDeletedException | A server entity the client is working with has been deleted |
qpid::amqp_0_10::ResourceDeletedException | A server entity the client is working with has been deleted |
qpid::framing::ResourceLimitExceededException | The client exceeded its resource allocation |
qpid::amqp_0_10::ResourceLimitExceededException | The client exceeded its resource allocation |
qpid::amqp_0_10::ResourceLockedException | The client attempted to work with a server entity to which it has no access because another client is working with it |
qpid::framing::ResourceLockedException | The client attempted to work with a server entity to which it has no access because another client is working with it |
qpid::sys::Runnable | Interface for objects that can be run, e.g |
qpid::sys::RWlock | RW 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::Selector | A selector identifies the set of log messages to enable |
qpid::broker::SemanticState | SemanticState holds the L3 and L4 state of an open session, whether attached to a channel or suspended |
qpid::framing::SendContent | Functor that sends frame to handler, refragmenting if necessary |
qpid::framing::SequenceNumber | 4-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 >::ScopedLimit | Temporarily set a lower relative limit on the serializer |
qpid::client::no_keyword::Session_0_10 | AMQP 0-10 synchronous session API |
qpid::client::Session_0_10 | AMQP 0-10 session API with keyword arguments |
qpid::amqp_0_10::SessionAbortedException | Raised when a session is destroyed due to an execution.exception |
qpid::broker::SessionAdapter | Per-channel protocol adapter |
qpid::client::SessionBase_0_10 | Base class for handles to an AMQP session |
qpid::amqp_0_10::SessionBusyDetachedException | The session is currently attached to another transport |
qpid::framing::SessionBusyException | The session is currently attached to another transport |
qpid::amqp_0_10::SessionBusyExpiredException | The session is currently attached to another transport |
qpid::amqp_0_10::SessionDestroyedException | Raised when the state of a session has been destroyed |
qpid::amqp_0_10::SessionDetachedException | Raised 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::SessionException | Raised 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::SessionExpiredException | Raised when a session with 0 timeout is unexpectedly detached and therefore expires and is destroyed |
qpid::amqp_0_10::SessionHandler | Base SessionHandler with logic common to both client and broker |
qpid::broker::SessionHandler | A SessionHandler is associated with each active channel |
qpid::SessionId | Identifier for a session |
qpid::broker::SessionManager | Create and manage SessionState objects |
qpid::SessionPoint | A point in the session |
qpid::broker::SessionState | Broker-side session state includes session's handler chains, which may themselves have state |
qpid::SessionState | Support for session idempotence barrier and resume as defined in AMQP 0-10 |
qpid::SharedObject< T > | Template to enforce shared object conventions |
qpid::sys::Shlib | Encapsulates a shared library handle |
qpid::broker::SignalHandler | Handle signals e.g |
qpid::log::SinkOptions | Logging sink options |
qpid::log::Statement | POD struct representing a logging statement in source code |
qpid::sys::StateMonitor< Enum, MaxEnum > | A monitor with an enum state value |
qpid::client::SubscriptionManager | A class to help create and manage subscriptions |
qpid::log::posix::SyslogFacility | Provides a type that can be passed to << and >> operators to convert syslog facility values to/from strings |
qpid::TcpAddress | TCP address of a broker - host:port |
qpid::broker::Tokens | A vector of string tokens |
qpid::broker::TopicPattern | Tokens that have been normalized as a pattern and can be matched with topic Tokens |
qpid::framing::TransferContent | Message content |
qpid::amqp_0_10::TransportBusyDetachedException | The transport is currently attached to another session |
qpid::framing::TransportBusyException | The transport is currently attached to another session |
qpid::amqp_0_10::TransportBusyExpiredException | The transport is currently attached to another session |
qpid::broker::TxAccept | Defines the transactional behaviour for accepts received by a transactional channel |
qpid::broker::TxPublish | Defines 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::UnauthorizedAccessException | The client attempted to work with a server entity to which it has no access due to security settings |
qpid::amqp_0_10::UnauthorizedAccessException | The client attempted to work with a server entity to which it has no access due to security settings |
qpid::amqp_0_10::Unit | A Unit contains a frame header and associated value |
qpid::amqp_0_10::UnknownIdsDetachedException | Command data was received prior to any use of the command-point control |
qpid::framing::UnknownIdsException | Command data was received prior to any use of the command-point control |
qpid::amqp_0_10::UnknownIdsExpiredException | Command data was received prior to any use of the command-point control |
qpid::amqp_0_10::UnknownType | Encode/decode an unknown type based on typecode |
qpid::Url | An AMQP URL contains a list of addresses |
qpid::framing::Uuid | A 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::Void | Void type |
qpid::sys::Waitable | A monitor that keeps track of waiting threads |
qpid::sys::Waitable::ScopedWait | Use 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::WriteEstimate | Estimate the amount of data that a connection can write between sending a doOutput notice and re-receiving it |