activemq-cpp-3.9.0
Class Hierarchy
This inheritance list is sorted roughly, but not completely, alphabetically:
[detail level 12345678]
 Cdecaf::util::concurrent::locks::AbstractOwnableSynchronizerBase class for locks that provide the notion of Ownership, the types of locks that are implemented using this base class would be owned by one specific Thread at any given time
 Cactivemq::core::ActiveMQAckHandlerInterface class that is used to give CMS Messages an interface to Ack themselves with
 Cactivemq::core::ActiveMQConstantsClass holding constant values for various ActiveMQ specific things Each constant is defined as an enumeration and has functions that convert back an forth between string and enum values
 Cactivemq::library::ActiveMQCPP
 Cactivemq::core::ActiveMQMessageAudit
 Cactivemq::util::ActiveMQMessageTransformation
 Cactivemq::util::AdvisorySupportSupport class that provides various static constants for use in constructing Destination names for the ActiveMQ advisory destinations
 Cdecaf::lang::AppendableAn object to which char sequences and values can be appended
 Cdecaf::internal::AprPoolWraps an APR pool object so that classes in decaf can create a static member for use in static methods where apr function calls that need a pool are made
 Cdecaf::lang::ArrayPointer< T >Decaf's implementation of a Smart Pointer that is a template on a Type and is Thread Safe if the default Reference Counter is used
 Cdecaf::lang::ArrayPointer< decaf::util::HashMap::HashMapEntry * >
 Cdecaf::lang::ArrayPointer< decaf::util::LinkedList< decaf::lang::Pointer< activemq::commands::MessageDispatch > > >
 Cdecaf::lang::ArrayPointer< unsigned char >
 Cdecaf::util::Arrays
 Cdecaf::util::concurrent::atomic::AtomicBooleanA boolean value that may be updated atomically
 Cdecaf::util::concurrent::atomic::AtomicRefCounter
 Cdecaf::util::concurrent::atomic::AtomicReference< T >An Pointer reference that may be updated atomically
 Cdecaf::internal::util::concurrent::Atomics
 Cdecaf::util::BitSetThis class implements a vector of bits that grows as needed
 Cactivemq::wireformat::openwire::utils::BooleanStreamManages the writing and reading of boolean data streams to and from a data source such as a DataInputStream or DataOutputStream
 Cdecaf::nio::BufferA container for data of a specific primitive type
 Cdecaf::internal::nio::BufferFactoryFactory class used by static methods in the decaf::nio package to create the various default version of the NIO interfaces
 Cdecaf::internal::util::ByteArrayAdapterThis class adapts primitive type arrays to a base byte array so that the classes can inter-operate on the same base byte array without copying data
 Cdecaf::util::concurrent::CallableTypeBase class of all Callable<T> objects, used to allow identification via type casting
 Cdecaf::security::cert::CertificateBase interface for all identity certificates
 Cdecaf::lang::CharSequenceA CharSequence is a readable sequence of char values
 Cdecaf::util::zip::ChecksumAn interface used to represent Checksum values in the Zip package
 Ccms::CloseableInterface for a class that implements the close method
 Cdecaf::io::CloseableInterface for a class that implements the close method
 Cactivemq::cmsutil::CmsAccessorBase class for activemq.cmsutil.CmsTemplate and other CMS-accessing gateway helpers, defining common properties such as the CMS cms.ConnectionFactory to operate on
 Cactivemq::util::CMSExceptionSupport
 Ccms::CMSPropertiesInterface for a Java-like properties object
 Ccode
 Cdecaf::util::Collections
 Cactivemq::state::CommandVisitorInterface for an Object that can visit the various Command Objects that are sent from and to this client
 Cdecaf::lang::Comparable< T >This interface imposes a total ordering on the objects of each class that implements it
 Cdecaf::lang::Comparable< ActiveMQDestination >
 Cdecaf::lang::Comparable< ActiveMQTempDestination >
 Cdecaf::lang::Comparable< bool >
 Cdecaf::lang::Comparable< Boolean >
 Cdecaf::lang::Comparable< BrokerId >
 Cdecaf::lang::Comparable< Byte >
 Cdecaf::lang::Comparable< ByteBuffer >
 Cdecaf::lang::Comparable< char >
 Cdecaf::lang::Comparable< Character >
 Cdecaf::lang::Comparable< CharBuffer >
 Cdecaf::lang::Comparable< ConnectionId >
 Cdecaf::lang::Comparable< ConsumerId >
 Cdecaf::lang::Comparable< Date >
 Cdecaf::lang::Comparable< Delayed >
 Cdecaf::lang::Comparable< Double >
 Cdecaf::lang::Comparable< double >
 Cdecaf::lang::Comparable< DoubleBuffer >
 Cdecaf::lang::Comparable< Float >
 Cdecaf::lang::Comparable< float >
 Cdecaf::lang::Comparable< FloatBuffer >
 Cdecaf::lang::Comparable< int >
 Cdecaf::lang::Comparable< IntBuffer >
 Cdecaf::lang::Comparable< Integer >
 Cdecaf::lang::Comparable< Level >
 Cdecaf::lang::Comparable< LocalTransactionId >
 Cdecaf::lang::Comparable< Long >
 Cdecaf::lang::Comparable< long long >
 Cdecaf::lang::Comparable< LongBuffer >
 Cdecaf::lang::Comparable< MessageId >
 Cdecaf::lang::Comparable< ProducerId >
 Cdecaf::lang::Comparable< SessionId >
 Cdecaf::lang::Comparable< Short >
 Cdecaf::lang::Comparable< short >
 Cdecaf::lang::Comparable< ShortBuffer >
 Cdecaf::lang::Comparable< TimeUnit >
 Cdecaf::lang::Comparable< TransactionId >
 Cdecaf::lang::Comparable< unsigned char >
 Cdecaf::lang::Comparable< URI >
 Cdecaf::lang::Comparable< UUID >
 Cdecaf::lang::Comparable< XATransactionId >
 Cdecaf::util::Comparator< T >A comparison function, which imposes a total ordering on some collection of objects
 Cdecaf::util::Comparator< ArrayPointer< T > >
 Cdecaf::util::Comparator< decaf::lang::Pointer< E > >
 Cdecaf::util::Comparator< E >
 Cdecaf::util::Comparator< Pointer< T, R > >
 Cdecaf::internal::util::concurrent::CompletionCondition
 Cactivemq::util::CompositeDataRepresents a Composite URI
 Cdecaf::util::concurrent::ConcurrentHashMap
 Cdecaf::util::concurrent::locks::ConditionCondition factors out the Mutex monitor methods (wait, notify and notifyAll) into distinct objects to give the effect of having multiple wait-sets per object, by combining them with the use of arbitrary Lock implementations
 Cactivemq::core::ConnectionAuditProvides the Auditing functionality used by Connections to attempt to filter out duplicate Messages
 Ccms::ConnectionFactoryDefines the interface for a factory that creates connection objects, the Connection objects returned implement the CMS Connection interface and hide the CMS Provider specific implementation details behind that interface
 Ccms::ConnectionMetaDataA ConnectionMetaData object provides information describing the Connection object
 Cactivemq::state::ConnectionState
 Cactivemq::state::ConsumerState
 Cdecaf::net::ContentHandlerFactoryDefines a factory interface for content handlers
 Cdecaf::util::concurrent::CountDownLatch
 Cct_data_s
 Cdecaf::net::DatagramPacketClass that represents a single datagram packet
 Cdecaf::io::DataInputThe DataInput interface provides for reading bytes from a binary stream and reconstructing from them data in any of the C++ primitive types
 Cdecaf::io::DataOutputThe DataOutput interface provides for converting data from any of the C++ primitive types to a series of bytes and writing these bytes to a binary stream
 Cactivemq::wireformat::openwire::marshal::DataStreamMarshallerBase class for all classes that marshal commands for Openwire
 Cdecaf::internal::net::ssl::DefaultSSLContextDefault SSLContext manager for the Decaf library
 Cdecaf::util::zip::DeflaterThis class compresses data using the DEFLATE algorithm (see specification)
 Ccms::DeliveryModeThis is an Abstract class whose purpose is to provide a container for the delivery mode enumeration for CMS messages
 Ccms::DestinationA Destination object encapsulates a provider-specific address
 Ccms::DestinationEventAn event class that is used to wrap information related to Destination add and remove events from the CMS Provider
 Cactivemq::commands::ActiveMQDestination::DestinationFilter
 Ccms::DestinationListenerA listener class that the client can implement to receive events related to Destination addition or removal on the CMS Provider
 Cactivemq::cmsutil::DestinationResolverResolves a CMS destination name to a Destination
 Cactivemq::core::DispatchDataSimple POCO that contains the information necessary to route a message to a specified consumer
 Cactivemq::core::DispatcherInterface for an object responsible for dispatching messages to consumers
 Cdecaf::lang::DYNAMIC_CAST_TOKEN
 Cdecaf::internal::security::EngineServes as a convenience class for classes in the Decaf Security package
 Cdecaf::util::logging::ErrorManagerErrorManager objects can be attached to Handlers to process any error that occur on a Handler during Logging
 Cexception
 Ccms::ExceptionListenerIf a CMS provider detects a serious problem, it notifies the client application through an ExceptionListener that is registered with the Connection
 Cdecaf::util::concurrent::ExecutorAn object that executes submitted decaf.lang.Runnable tasks
 Cdecaf::util::concurrent::ExecutorsImplements a set of utilities for use with Executors, ExecutorService, ThreadFactory, and Callable types, as well as providing factory methods for instance of these types configured for the most common use cases
 Cdecaf::internal::util::concurrent::ExecutorsSupportVarious support methods for use in Executors and surrounding classes
 Cdecaf::io::FileDescriptorThis class servers as an opaque wrapper around an underlying OS level resource that can be used as a source / sink for byte level data such as sockets and files
 Cdecaf::net::FileNameMapDefines a scheme for mapping a filename type to a MIME content type
 Cdecaf::util::logging::FilterA Filter can be used to provide fine grain control over what is logged, beyond the control provided by log levels
 Cdecaf::io::FlushableA Flushable is a destination of data that can be flushed
 Cdecaf::util::logging::FormatterA Formatter provides support for formatting LogRecords
 Cactivemq::transport::FutureResponseA container that holds a response object
 Cdecaf::util::concurrent::FutureType
 Cgz_header_s
 Cgz_state
 Cdecaf::util::HashCodeUnaryBase< T >
 Cdecaf::util::HashCodeUnaryBase< bool >
 Cdecaf::util::HashCodeUnaryBase< char >
 Cdecaf::util::HashCodeUnaryBase< const std::string & >
 Cdecaf::util::HashCodeUnaryBase< const T & >
 Cdecaf::util::HashCodeUnaryBase< const T * >
 Cdecaf::util::HashCodeUnaryBase< decaf::lang::Pointer< T > >
 Cdecaf::util::HashCodeUnaryBase< double >
 Cdecaf::util::HashCodeUnaryBase< float >
 Cdecaf::util::HashCodeUnaryBase< int >
 Cdecaf::util::HashCodeUnaryBase< long long >
 Cdecaf::util::HashCodeUnaryBase< short >
 Cdecaf::util::HashCodeUnaryBase< unsigned int >
 Cdecaf::util::HashCodeUnaryBase< unsigned long long >
 Cdecaf::util::HashCodeUnaryBase< unsigned short >
 Cdecaf::util::HashCodeUnaryBase< wchar_t >
 Cdecaf::internal::util::HexStringParser
 Cactivemq::wireformat::openwire::utils::HexTableMaps hexidecimal strings to the value of an index into the table, i.e
 Cactivemq::util::IdGenerator
 Cdecaf::net::InetAddressRepresents an IP address
 Cinflate_state
 Cdecaf::util::zip::InflaterThis class uncompresses data that was compressed using the DEFLATE algorithm (see specification)
 Cinternal_state
 Cdecaf::lang::Iterable< E >Implementing this interface allows an object to be cast to an Iterable type for generic collections API calls
 Cdecaf::lang::Iterable< activemq::util::PrimitiveValueNode >
 Cdecaf::lang::Iterable< activemq::util::ServiceListener * >
 Cdecaf::lang::Iterable< cms::Connection * >
 Cdecaf::lang::Iterable< cms::Destination * >
 Cdecaf::lang::Iterable< cms::MessageConsumer * >
 Cdecaf::lang::Iterable< cms::MessageProducer * >
 Cdecaf::lang::Iterable< cms::Session * >
 Cdecaf::lang::Iterable< decaf::internal::util::Resource * >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::commands::ActiveMQDestination > >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::commands::Command > >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::commands::DestinationInfo > >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::commands::MessageDispatch > >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::core::Synchronization > >
 Cdecaf::lang::Iterable< decaf::lang::Pointer< activemq::transport::Transport > >
 Cdecaf::lang::Iterable< decaf::net::decaf::net::URI >
 Cdecaf::lang::Iterable< decaf::net::URI >
 Cdecaf::lang::Iterable< K >
 Cdecaf::lang::Iterable< MapEntry< K, V > >
 Cdecaf::lang::Iterable< PrimitiveValueNode >
 Cdecaf::lang::Iterable< V >
 Cdecaf::util::Iterator< E >Defines an object that can be used to iterate over the elements of a collection
 Cdecaf::util::Iterator< K >
 Cdecaf::util::Iterator< MapEntry< K, V > >
 Cdecaf::util::Iterator< T >
 Cdecaf::util::Iterator< V >
 Cdecaf::security::KeyThe Key interface is the top-level interface for all keys
 Cstd::less< decaf::lang::ArrayPointer< T > >An override of the less function object so that the Pointer objects can be stored in STL Maps, etc
 Cstd::less< decaf::lang::Pointer< T > >An override of the less function object so that the Pointer objects can be stored in STL Maps, etc
 Cdecaf::util::concurrent::LockA wrapper class around a given synchronization mechanism that provides automatic release upon destruction
 Cdecaf::util::concurrent::locks::LockLock implementations provide more extensive locking operations than can be obtained using synchronized statements
 Cdecaf::util::concurrent::locks::LockSupportBasic thread blocking primitives for creating locks and other synchronization classes
 Cdecaf::util::logging::LoggerA Logger object is used to log messages for a specific system or application component
 Cdecaf::util::logging::LoggerHierarchy
 Cdecaf::util::logging::LogManagerThere is a single global LogManager object that is used to maintain a set of shared state about Loggers and log services
 Cdecaf::util::logging::LogRecordLogRecord objects are used to pass logging requests between the logging framework and individual log Handlers
 Cdecaf::util::logging::LogWriter
 Cactivemq::util::LongSequenceGeneratorThis class is used to generate a sequence of long long values that are incremented each time a new value is requested
 Cdecaf::util::MapEntry< K, V >
 Cdecaf::util::logging::MarkBlockLoggerDefines a class that can be used to mark the entry and exit from scoped blocks
 Cactivemq::wireformat::MarshalAware
 Cactivemq::wireformat::openwire::marshal::generated::MarshallerFactoryUsed to create marshallers for a specific version of the wire protocol
 Cactivemq::util::MarshallingSupport
 Cdecaf::lang::MathThe class Math contains methods for performing basic numeric operations such as the elementary exponential, logarithm, square root, and trigonometric functions
 Ccms::MessageRoot of all messages
 Ccms::MessageAvailableListenerA listener interface similar to the MessageListener interface
 Cactivemq::cmsutil::MessageCreatorCreates the user-defined message to be sent by the CmsTemplate
 Cdecaf::security::MessageDigestThis MessageDigest class provides applications the functionality of a message digest algorithm, such as MD5 or SHA
 Ccms::MessageEnumerationDefines an object that enumerates a collection of Messages
 Ccms::MessageListenerA MessageListener object is used to receive asynchronously delivered messages
 Cactivemq::wireformat::openwire::utils::MessagePropertyInterceptorUsed the base ActiveMQMessage class to intercept calls to get and set properties in order to capture the calls that use the reserved JMS properties and get and set them in the OpenWire Message properties
 Ccms::MessageTransformerProvides an interface for clients to transform cms::Message objects inside the CMS MessageProducer and MessageConsumer objects before the message's are sent or received
 Cdecaf::internal::util::concurrent::MonitorHandle
 Cdecaf::internal::net::NetworkInternal class used to manage Networking related resources and hide platform dependent calls from the higher level API
 Cdecaf::lang::NumberThe abstract class Number is the superclass of classes Byte, Double, Float, Integer, Long, and Short
 Cdecaf::internal::net::ssl::openssl::OpenSSLParametersContainer class for parameters that are Common to OpenSSL socket classes
 Cdecaf::internal::util::concurrent::PlatformThread
 Cactivemq::core::PrefetchPolicyInterface for a Policy object that controls message Prefetching on various destination types in ActiveMQ-CPP
 Cactivemq::wireformat::openwire::marshal::PrimitiveTypesMarshallerThis class wraps the functionality needed to marshal a primitive map to the Openwire Format's expectation of what the map looks like on the wire
 Cactivemq::util::PrimitiveValueNode::PrimitiveValueDefine a union type comprised of the various types
 Cactivemq::util::PrimitiveValueConverterClass controls the conversion of data contained in a PrimitiveValueNode from one type to another
 Cactivemq::util::PrimitiveValueNodeClass that wraps around a single value of one of the many types
 Cdecaf::security::PrincipalBase interface for a principal, which can represent an individual or organization
 Cdecaf::util::PriorityQueueBase
 Cactivemq::cmsutil::ProducerCallbackCallback for sending a message to a CMS destination
 Cactivemq::state::ProducerState
 Cdecaf::util::PropertiesJava-like properties class for mapping string names to string values
 Cdecaf::util::logging::PropertiesChangeListenerDefines the interface that classes can use to listen for change events on Properties
 Cdecaf::security::ProviderThis class represents a "provider" for the Decaf Security API, where a provider implements some or all parts of Decaf Security
 Cdecaf::security::ProviderService
 Cdecaf::net::Proxy
 Cdecaf::util::RandomRandom Value Generator which is used to generate a stream of pseudorandom numbers
 Cdecaf::lang::ReadableA Readable is a source of characters
 Cdecaf::util::concurrent::locks::ReadWriteLockA ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing
 Cactivemq::core::RedeliveryPolicyInterface for a RedeliveryPolicy object that controls how message Redelivery is handled in ActiveMQ-CPP when a transaction is rolled back
 CREFCOUNTER
 Cdecaf::util::concurrent::RejectedExecutionHandlerA handler for tasks that cannot be executed by a ThreadPoolExecutor
 Cdecaf::internal::util::ResourceInterface for all Managed Resources in Decaf, these objects are added to the Runtime System and are destroyed at shutdown
 Cactivemq::cmsutil::ResourceLifecycleManagerManages the lifecycle of a set of CMS resources
 Cdecaf::internal::util::ResourceLifecycleManager
 Cactivemq::transport::mock::ResponseBuilderInterface for all Protocols to implement that defines the behavior of the Broker in response to messages of that protocol
 Cactivemq::transport::ResponseCallbackAllows an async send to complete at a later time via a Response event
 Cdecaf::lang::RunnableInterface for a runnable object - defines a task that can be run by a thread
 Cdecaf::lang::Runtime
 Cdecaf::internal::util::concurrent::RWLOCK
 Cdecaf::security::Security
 Cdecaf::internal::security::SecurityRuntimeInternal class used to manage Security related resources and hide platform dependent calls from the higher level API
 Cdecaf::security::SecuritySpiBase class used as a Marker for all Security Provider Interface classes in the Decaf Security API
 Cdecaf::util::concurrent::SemaphoreA counting semaphore
 Cdecaf::net::ServerSocketThis class implements server sockets
 Cdecaf::net::ServerSocketFactoryClass used to create Server Sockets, subclasses can be created that create certain types of server sockets according to specific policies
 Cactivemq::util::ServiceBase interface for all classes that run as a Service inside the application
 Cactivemq::util::ServiceListenerListener interface for observers of Service related events
 Cdecaf::internal::security::ServiceRegistryServes as a registry for all the Providers for services using the naming format of "ServiceName.Algorithm"
 Cactivemq::util::ServiceStopper
 Cactivemq::cmsutil::SessionCallbackCallback for executing any number of operations on a provided CMS Session
 Cactivemq::cmsutil::SessionPoolA pool of CMS sessions from the same connection and with the same acknowledge mode
 Cactivemq::state::SessionState
 Cdecaf::util::logging::SimpleLogger
 Cdecaf::net::SocketAddressBase class for protocol specific Socket addresses
 Cdecaf::net::SocketErrorStatic utility class to simplify handling of error codes for socket operations
 Cdecaf::net::SocketFactoryThe SocketFactory is used to create Socket objects and can be sub-classed to provide other types of Sockets or Sockets with varying configurations
 Cdecaf::net::SocketImplFactoryFactory class interface for a Factory that creates ScoketImpl objects
 Cdecaf::net::SocketOptions
 Cdecaf::net::ssl::SSLContextRepresents on implementation of the Secure Socket Layer for streaming based sockets
 Cdecaf::net::ssl::SSLContextSpiDefines the interface that should be provided by an SSLContext provider
 Cdecaf::net::ssl::SSLParameters
 Cactivemq::commands::BrokerError::StackTraceElement
 Ccms::StartableInterface for a class that implements the start method
 Cdecaf::lang::STATIC_CAST_TOKEN
 Cactivemq::core::ActiveMQConstants::StaticInitializer
 Cactivemq::wireformat::stomp::StompCommandConstants
 Cactivemq::wireformat::stomp::StompFrameA Stomp-level message frame that encloses all messages to and from the broker
 Cactivemq::wireformat::stomp::StompHelperUtility Methods used when marshaling to and from StompFrame's
 Ccms::StoppableInterface for a class that implements the stop method
 Cdecaf::util::StringTokenizerClass that allows for parsing of string based on Tokens
 Cdecaf::internal::util::StringUtils
 Cactivemq::util::SuspendableInterface for any resouce that support a suspend / resume style of operation
 Cdecaf::util::concurrent::SynchronizableThe interface for all synchronizable objects (that is, objects that can be locked and unlocked)
 Cactivemq::core::SynchronizationTransacted Object Synchronization, used to sync the events of a Transaction with the items in the Transaction
 Cdecaf::lang::SystemStatic methods for accessing system level resources and performing some system dependent tasks such as looking up environment values and copying memory and arrays
 Cactivemq::threads::TaskRepresents a unit of work that requires one or more iterations to complete
 Cactivemq::threads::TaskRunner
 Cdecaf::util::concurrent::ThreadFactoryPublic interface ThreadFactory
 Cdecaf::lang::ThreadGroup
 Cdecaf::internal::util::concurrent::ThreadHandle
 Cdecaf::internal::util::concurrent::Threading
 Cdecaf::internal::util::concurrent::ThreadLocalImpl
 Cdecaf::util::TimerA facility for threads to schedule tasks for future execution in a background thread
 Cdecaf::internal::util::TimerTaskHeapA Binary Heap implemented specifically for the Timer class in Decaf Util
 Cactivemq::state::TransactionState
 Cdecaf::internal::util::concurrent::Transferer< E >Shared internal API for dual stacks and queues
 Cactivemq::transport::TransportFactoryDefines the interface for Factories that create Transports or TransportFilters
 Cactivemq::transport::TransportListenerA listener of asynchronous exceptions from a command transport object
 Cactivemq::transport::TransportRegistryRegistry of all Transport Factories that are available to the client at runtime
 Ctree_desc_s
 Cdecaf::lang::Types
 Cdecaf::lang::Thread::UncaughtExceptionHandlerInterface for handlers invoked when a Thread abruptly terminates due to an uncaught exception
 Cdecaf::internal::net::URIEncoderDecoder
 Cdecaf::internal::net::URIHelperHelper class used by the URI classes in encoding and decoding of URI's
 Cactivemq::transport::failover::URIPool
 Cactivemq::util::URISupport
 Cdecaf::internal::net::URITypeBasic type object that holds data that composes a given URI
 Cdecaf::net::URLClass URL represents a Uniform Resource Locator, a pointer to a "resource" on the World Wide Web
 Cdecaf::net::URLConnectionConcrete implementations of the abstract
 Cdecaf::net::URLDecoder
 Cdecaf::net::URLEncoder
 Cdecaf::net::URLStreamHandlerThe abstract class URLStreamHandler is the common superclass for all stream protocol handlers
 Cdecaf::net::URLStreamHandlerFactoryDefines a factory which creates an URLStreamHandler for a specified protocol
 Cdecaf::internal::net::URLStreamHandlerManager
 Cdecaf::internal::net::URLTypeBasic type object that holds data that composes a given URL
 Cdecaf::internal::net::URLUtils
 Cactivemq::util::Usage
 Cactivemq::wireformat::WireFormatProvides a mechanism to marshal commands into and out of packets or into and out of streams, Channels and Datagrams
 Cactivemq::wireformat::WireFormatFactoryThe WireFormatFactory is the interface that all WireFormatFactory classes must extend
 Cactivemq::wireformat::WireFormatRegistryRegistry of all WireFormat Factories that are available to the client at runtime
 Ccms::XAConnectionFactoryThe XAConnectionFactory interface is specialized interface that defines an ConnectionFactory that creates Connection instance that will participate in XA Transactions
 Ccms::XAResourceThe XAResource interface is a CMS mapping of the industry standard XA interface based on the X/Open CAE Specification (Distributed Transaction Processing: The XA Specification)
 Ccms::XidAn interface which provides a mapping for the X/Open XID transaction identifier structure
 Cz_stream_s
 CT