CAllocatedArray< T > | An array allocated on the heap with a length determined at runtime |
CAllocatedPath | A path name in the native file system character set |
CAllocatedSocketAddress | |
CAllocatedString< T > | A string pointer whose memory is managed by this class |
CSLES::AndroidSimpleBufferQueue | OO wrapper for an OpenSL/ES SLAndroidSimpleBufferQueueItf variable |
CArchiveFile | |
CArchivePlugin | |
CArchiveVisitor | |
CAudioFormat | This structure describes the format of a raw PCM stream |
CAudioOutput | |
▶CAudioOutputClient | An interface between the AudioOutput and the #Player |
CPlayerControl | |
CAudioOutputPlugin | A plugin which controls an audio output device |
CAudioOutputSource | Source of audio data to be played by an AudioOutput |
CAudioOutputWrapper< T > | |
▶CAvahiPoll | |
CMyAvahiPoll | |
CAvioStream | |
CBasicStringBuffer< T, CAPACITY > | A statically allocated string buffer |
▶CBasicStringBuffer< char, CAPACITY > | |
CStringBuffer< CAPACITY > | |
CBindMethodDetail::BindMethodWrapperGenerator< T, M, method, S > | Generate a wrapper function |
CBindMethodDetail::BindMethodWrapperGenerator2< T, M, method, R, Args > | Generate a wrapper function |
▶CBindMethodDetail::BindMethodWrapperGenerator2< T, M, method, R, Args... > | |
CBindMethodDetail::BindMethodWrapperGenerator< T, M, method, R(Args...)> | |
CBlockParam | |
CBoundMethod< S > | This object stores a function pointer wrapping a method, and a reference to an instance of the method's class |
CBoundMethod< R(Args...)> | |
CBufferedOutputStream | An OutputStream wrapper that buffers its output to reduce the number of OutputStream::Write() calls |
CBufferedReader | |
CCancellableList< T, CT > | |
CCancellableList< NfsCallback, CancellableCallback > | |
CCircularBuffer< T > | A circular buffer |
CCircularBuffer< uint8_t > | |
CClientList | |
CClientMessage | A client-to-client message |
CCommandListBuilder | |
CCommonExpatParser | A specialization of ExpatParser that provides the most common callbacks as virtual methods |
CPlaylistInfo::CompareName | |
CCompressorConfig | Configuration values for the compressor object |
CConfigBlock | |
CConfigData | |
CConfigParam | |
CConfigTemplate | |
CTag::const_iterator | |
CConstBuffer< T > | A reference to a memory area that is read-only |
▶CConstBuffer< char > | |
CStringView | |
▶CConstBuffer< const char *> | |
CRequest | |
CConstBuffer< uint8_t > | |
CConstBuffer< void > | |
CContentDirectoryService | Content Directory Service class |
CCriticalSection | Wrapper for a CRITICAL_SECTION, backend for the Mutex class |
CCrossFadeSettings | |
CCueParser | |
CCurlEasy | An OO wrapper for a "CURL*" (a libCURL "easy" handle) |
CCurlMulti | An OO wrapper for a "CURLM*" (a libCURL "multi" handle) |
CCurlResponseHandler | |
CCurlSlist | OO wrapper for "struct curl_slist *" |
▶CDatabase | |
CSimpleDatabase | |
CDatabaseEditor | |
CDatabaseListener | An object that listens to events from the Database |
CDatabasePlugin | |
CDatabaseSelection | |
CDatabaseStats | |
CDecoderBuffer | This objects handles buffered reads in decoder plugins easily |
▶CDecoderClient | An interface between the decoder plugin and the MPD core |
CDecoderBridge | A bridge between the DecoderClient interface and the MPD core (DecoderControl, MusicPipe etc.) |
CDecoderControl | |
CDecoderPlugin | |
▶CDeferredMonitor | Defer execution of an event into an EventLoop |
CCurlGlobal | Manager for the global CURLM object |
CCurlRequest | |
CDeferredCall | Invoke a method call in the EventLoop |
CHttpdOutput | |
CMaskMonitor | Manage a bit mask of events that have occurred |
CNfsConnection | An asynchronous connection to a NFS server |
CNfsFileReader | A helper class which helps with reading from a file |
CUpdateRemoveService | This class handles Song removal |
CUpdateService | This class manages the update queue and runs the update thread |
CDeleteDisposer | A disposer for boost::intrusive that invokes the "delete" operator on the given pointer |
CDetachedSong | |
CDffDsdUint64 | |
CDirectory | |
CDirectoryReader | Reader for directory entries |
CSong::Disposer | |
CDivideString | Split a given constant string at a separator character |
CDomain | |
CDsdId | |
CDsdUint64 | |
▶Cduration | |
CSignedSongTime | A variant of SongTime that is based on a signed integer |
CSongTime | A time stamp within a song |
▶CEncoder | |
COggEncoder | An abstract base class which contains code common to all encoders with Ogg container output |
CEncoderPlugin | |
CSLES::Engine | OO wrapper for an OpenSL/ES SLEngineItf variable |
CMemoryStorageDirectoryReader::Entry | |
CEPollFD | A class that wraps Linux epoll |
CEventFD | A class that wraps eventfd() |
▶CEventLoopHolder | A utility class which, when used as the first base class, ensures that the EventLoop gets initialized before the other base classes |
CInstance | |
CEventPipe | A pipe that can be used to trigger an event to the read side |
▶Cexception | |
CZlibError | |
CExcludeList | |
CExpatNamespaceSeparator | |
CExpatParser | |
▶CF | |
CScopeExitGuard< F > | Internal class |
CFfmpegBuffer | |
CFileDescriptor | An OO wrapper for a UNIX file descriptor |
CFileInfo | |
CFilter | |
CFilterObserver | A helper class which observes calls to a PreparedFilter and allows the caller to access the Filter instances created by it |
CFilterPlugin | |
▶CFlacInput | This class wraps an InputStream in libFLAC stream decoder callbacks |
CFlacDecoder | |
CFlacMetadataChain | |
CFLACMetadataIterator | |
CFlacPcmImport | This class imports libFLAC PCM data into a PCM format supported by MPD |
CFlacStreamDecoder | OO wrapper for a FLAC__StreamDecoder |
CFloatToIntegerSampleConvert< F, Traits > | Convert from float to an integer sample format |
▶CForeignFifoBuffer< T > | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CDynamicFifoBuffer< T > | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CDynamicFifoBuffer< char > | |
CDynamicFifoBuffer< uint8_t > | |
CJava::GlobalRef< T > | Hold a global reference on a JNI object |
▶CJava::GlobalRef< jobject > | |
▶CJava::Object | |
CContext | |
CGluePcmResampler | A glue class that integrates a PcmResampler and automatically converts source data to the sample format required by the PcmResampler instance |
CHugeAllocation | Automatic huge memory allocation management |
CIcuCompare | This class can compare one string ("needle") with lots of other strings ("haystacks") efficiently, ignoring case |
CIcyMetaDataParser | |
CId3Delete | |
▶CIdleMonitor | An event that runs when the EventLoop has become idle, before waiting for more events |
▶CFullyBufferedSocket | A BufferedSocket specialization that adds an output buffer |
CClient | |
CMultiSocketMonitor | Similar to SocketMonitor, but monitors multiple sockets |
CNfsManager | A manager for NFS connections |
CIdTable | A table that maps id numbers to position numbers |
CInputPlugin | |
▶CInputStream | |
CAsyncInputStream | Helper class for moving asynchronous (non-blocking) InputStream implementations to the I/O thread |
▶CProxyInputStream | An InputStream that forwards all methods call to another InputStream instance |
CIcyInputStream | An InputStream filter that parses Icy metadata |
CThreadInputStream | Helper class for moving InputStream implementations with blocking backend library implementation to a dedicated thread |
CIntegerToFloatSampleConvert< F, Traits > | Convert from an integer sample format to float |
CQueue::Item | One element of the queue: basically a song plus some queue specific information attached |
CSongFilter::Item | |
CIterableSplitString | Split a string at a certain separator character into sub strings and allow iterating over the segments |
CIterableSplitString::Iterator | |
CLazyRandomEngine | A random engine that will be created and seeded on demand |
CLeftShiftSampleConvert< SF, DF, ST, DT > | Convert from one integer sample format to another by shifting bits to the left |
CLightDirectory | A reference to a directory |
▶CLightSong | A reference to a song file |
CPrefixedLightSong | |
▶Clist | |
CPlaylistVector | |
▶Clist_base_hook | |
CCancellablePointer< T > | |
CCancellablePointer< NfsCallback > | |
CClient | |
CHttpdClient | |
▶CJava::LocalRef< T > | Hold a local reference on a JNI object |
CJava::File | Wrapper for a java.io.File object |
▶CJava::LocalRef< jclass > | |
CJava::Class | Wrapper for a local "jclass" reference |
▶CJava::LocalRef< jstring > | |
CJava::String | Wrapper for a local "jstring" reference |
CLocatedUri | |
CPulse::LockGuard | |
CDirectory::LookupResult | |
CManual< T > | Container for an object that gets constructed and destructed manually |
CBindMethodDetail::MethodSignatureHelper< M > | Helper class which introspects a method pointer type |
CBindMethodDetail::MethodSignatureHelper< R(T::*)(Args...)> | |
CBindMethodDetail::MethodWithSignature< T, S > | Helper class which converts a signature type to a method pointer type |
CBindMethodDetail::MethodWithSignature< T, R(Args...)> | |
CBindMethodDetail::MethodWrapperWithSignature< S > | Helper class which converts a plain function signature type to a wrapper function pointer type |
CBindMethodDetail::MethodWrapperWithSignature< R(Args...)> | |
CMixer | |
▶CMixerListener | An interface that listens on events from mixer plugins |
CPartition | A partition of the Music Player Daemon |
CMixerPlugin | |
CMixRampInfo | |
CMultipleOutputs | |
CMusicBuffer | An allocator for MusicChunk objects |
CMusicChunk | A chunk of music data |
CMusicPipe | A queue of MusicChunk objects |
CNarrowPath | A path name that uses the regular (narrow) "char" |
CNeighborExplorer | An object that explores the neighborhood for music servers |
CNeighborGlue | A class that initializes and opens all configured neighbor plugins |
CNeighborInfo | |
CNeighborListener | An interface that listens on events from neighbor plugins |
CNeighborPlugin | |
CNeonFloatTo16 | Convert floating point samples to 16 bit signed integer using ARM NEON |
▶CNfsCallback | Callbacks for an asynchronous libnfs operation |
CBlockingNfsOperation | Utility class to implement a blocking NFS call using the libnfs async API |
CNfsFileReader | A helper class which helps with reading from a file |
▶CNfsLease | |
CBlockingNfsOperation | Utility class to implement a blocking NFS call using the libnfs async API |
CNfsFileReader | A helper class which helps with reading from a file |
Cnoise_shape_ctx_s | |
Cnotify | |
CSLES::Object | OO wrapper for an OpenSL/ES SLObjectItf variable |
COggStreamState | |
COggSyncState | Wrapper for an ogg_sync_state |
▶COggVisitor | Abstract class which iterates over Ogg packets in a Reader |
COggDecoder | |
COptionDef | Command line option definition |
COptionParser | Command line option parser |
Coptions | |
COpusReader | |
▶COutputStream | |
CFileOutputStream | |
CGzipOutputStream | A filter that compresses data written to it using zlib, forwarding compressed data in the "gzip" format |
CStdioOutputStream | |
CPage | A dynamically allocated buffer which keeps track of its reference count |
CPcmExport::Params | |
CPathTraitsFS | This class describes the nature of a native filesystem path |
CPathTraitsUTF8 | This class describes the nature of a MPD internal filesystem path |
CCurlRequest::Pause | CurlResponseHandler::OnData() shall throw this to pause the stream |
CPcmBuffer | Manager for a temporary buffer which grows as needed |
CPcmChannelsConverter | A class that converts samples from one format to another |
CPcmConvert | This object is statically allocated (within another struct), and holds buffer allocations and the state for all kinds of PCM conversions |
CPcmDither | |
CPcmDsd | Wrapper for the dsd2pcm library |
CPcmExport | An object that handles export of PCM samples to some instance outside of MPD |
CPcmFormatConverter | A class that converts samples from one format to another |
▶CPcmResampler | This is an interface for plugins that convert PCM data to a specific sample rate |
CFallbackPcmResampler | A naive resampler that is used when no external library was found (or when the user explicitly asks for bad quality) |
CLibsampleratePcmResampler | A resampler using libsamplerate |
CSoxrPcmResampler | A resampler using soxr |
CPcmVolume | A class that converts samples from one format to another |
CPeakBuffer | A FIFO-like buffer that will allocate more memory on demand to allow large peaks |
CPeriodClock | This is a stopwatch which saves the timestamp of an event, and can check whether a specified time span has passed since then |
CPidFile | |
CSLES::Play | OO wrapper for an OpenSL/ES SLPlayItf variable |
Cplayer_status | |
▶CPlayerListener | |
CPartition | A partition of the Music Player Daemon |
Cplaylist | |
Cplaylist_plugin | |
CPlaylistInfo | A directory entry pointing to a playlist file |
CPollGroupEPoll | |
CPollGroupPoll | |
CPollGroupWinSelect | |
CPollResultEPoll | |
CPollResultGeneric | |
▶CPosixCond | Low-level wrapper for a pthread_cond_t |
CCond | |
▶CPosixMutex | Low-level wrapper for a pthread_mutex_t |
CMutex | |
CPreparedEncoder | |
CPreparedFilter | |
CQueue | A queue of songs |
▶CQueueListener | |
CPartition | A partition of the Music Player Daemon |
CRangeArg | |
▶CReader | An interface that can read bytes from a stream until the stream ends |
CAutoGunzipReader | A filter that detects gzip compression and optionally inserts a GunzipReader |
CDecoderReader | A wrapper for decoder_read() which implements the Reader interface |
CFileReader | |
CGunzipReader | A filter that decompresses data using zlib |
CInputStreamReader | A Reader implementation which forwards all read calls to InputStream::Read() and logs errors |
CPeekReader | A filter that allows the caller to peek the first few bytes without consuming them |
CRefCount | |
CReplayGainConfig | |
CReplayGainInfo | |
CReplayGainTuple | |
CAudioOutput::Request | Additional data for command |
CResponse | |
CReusableArray< T, M > | Manager for a temporary array which grows as needed |
CReusableArray< uint8_t, 8192 > | |
CRightShiftSampleConvert< SF, DF, ST, DT > | Convert from one integer sample format to another by shifting bits to the right |
▶Cruntime_error | |
CDatabaseError | |
CExpatError | |
CPlaylistError | |
CPluginUnavailable | An exception class which is used by plugin initializers to indicate that this plugin is unavailable |
CProtocolError | |
CSqliteError | |
CSampleTraits< F > | This template describes the specified SampleFormat |
CSampleTraits< SampleFormat::DSD > | |
CSampleTraits< SampleFormat::FLOAT > | |
CSampleTraits< SampleFormat::S16 > | |
CSampleTraits< SampleFormat::S24_P32 > | |
CSampleTraits< SampleFormat::S32 > | |
CSampleTraits< SampleFormat::S8 > | |
CScopeBulkEdit | Begin a "bulk edit" and commit it automatically |
CScopeDatabaseLock | |
CScopeDatabaseUnlock | Unlock the database while in the current scope |
CScopeExitTag | Internal class |
CScopeUnlock | Within the scope of an instance, this class will keep a Mutex unlocked |
▶CServerSocket | A socket that accepts incoming stream connections (e.g |
CHttpdOutput | |
▶Cset | |
CTagSet | A set of Tag objects |
CSharedPipeConsumer | A utility class which helps with consuming data from a MusicPipe |
CSignalFD | A class that wraps signalfd() |
CSliceBuffer< T > | This class pre-allocates a certain number of objects, and allows callers to allocate and free these objects ("slices") |
CSliceBuffer< MusicChunk > | |
CSocketAddress | An OO wrapper for struct sockaddr |
CSocketErrorMessage | Helper class that formats a socket error message into a human-readable string |
▶CSocketMonitor | Monitor events on a socket |
▶CBufferedSocket | A SocketMonitor specialization that adds an input buffer |
CFullyBufferedSocket | A BufferedSocket specialization that adds an output buffer |
CHttpdClient | |
CEventLoop | An event loop that polls for events on file/socket descriptors |
CInotifySource | |
CNfsConnection | An asynchronous connection to a NFS server |
CSocketSet | |
CSong | A song file inside the configured music directory |
▶CSongEnumerator | An object which provides serial access to a number of Song objects |
CMemorySongEnumerator | |
CSongFilter | |
CSongLoader | A utility class that loads a DetachedSong object by its URI |
CStaticFifoBuffer< T, size > | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CStaticFifoBuffer< Bytef, 4096 > | |
CStaticFifoBuffer< char, 4096 > | |
CStaticFifoBuffer< uint8_t, 8192 > | |
CStaticSocketAddress | An OO wrapper for struct sockaddr_storage |
CStopDecoder | Throw an instance of this class to stop decoding the current song (successfully) |
▶CStorage | |
CCompositeStorage | A Storage implementation that combines multiple other Storage instances in one virtual tree |
▶CStorageDirectoryReader | |
CMemoryStorageDirectoryReader | A StorageDirectoryReader implementation that returns directory entries from a memory allocation |
CStorageFileInfo | |
CStoragePlugin | |
▶CStringPointer< T > | Simple OO wrapper for a const string pointer |
CPath | A path name in the native file system character set |
CTag | The meta information about a song file |
Ctag_table | |
CTagBuilder | A class that constructs Tag objects |
CTagHandler | A callback table for receiving metadata of a song |
CTagItem | One tag value |
CTagLess | Helper class for TagSet which compares two Tag objects |
CTextFile | |
CTextInputStream | |
CThread | |
CThreadId | A low-level identification for a thread |
▶CTimeoutMonitor | This class monitors a timeout |
CClient | |
CCurlGlobal | Manager for the global CURLM object |
CInotifyQueue | |
CMultiSocketMonitor | Similar to SocketMonitor, but monitors multiple sockets |
CNfsConnection | An asynchronous connection to a NFS server |
CStateFile | |
CTimer | |
CTokenizer | |
CJava::TrivialRef< T > | Container for a global reference to a JNI object that gets initialised and deinitialised explicitly |
▶CJava::TrivialRef< jclass > | |
CJava::TrivialClass | Wrapper for a global "jclass" reference |
CUpdateQueue | |
CUpdateQueueItem | |
CUpdateWalk | |
▶CUpnpCallback | A class that is supposed to be used for libupnp asynchronous callbacks |
CUPnPDeviceDirectory | Manage UPnP discovery and maintain a directory of active devices |
CUPnPDevice | Data holder for a UPnP device, parsed from the XML description obtained during discovery |
CUPnPDirContent | Image of a MediaServer Directory Service container (directory), possibly containing items and subordinate containers |
CUPnPDirObject | UpnP Media Server directory entry, converted from XML data |
CUPnPDiscoveryListener | |
CUpnpIxmlDeleter | |
CUPnPService | UPnP Description phase: interpreting the device description which we downloaded from the URL obtained by the discovery phase |
CUriSuffixBuffer | |
CVorbisComment | OO wrapper for a #vorbis_comment instance |
CWindowsCond | Wrapper for a CONDITION_VARIABLE, backend for the Cond class |
CWorkQueue< T > | A WorkQueue manages the synchronisation around a queue of work items, where a number of client threads queue tasks and a number of worker threads take and execute them |
CWorkQueue< std::unique_ptr< DiscoveredTask > > | |
CWritableBuffer< T > | A reference to a memory area that is writable |
CWritableBuffer< void > | |