▶NBindMethodDetail | |
CBindMethodWrapperGenerator | Generate a wrapper function |
CBindMethodWrapperGenerator2 | Generate a wrapper function |
CBindMethodWrapperGenerator< T, M, method, R(Args...)> | |
CMethodSignatureHelper | Helper class which introspects a method pointer type |
CMethodSignatureHelper< R(T::*)(Args...)> | |
CMethodWithSignature | Helper class which converts a signature type to a method pointer type |
CMethodWithSignature< T, R(Args...)> | |
CMethodWrapperWithSignature | Helper class which converts a plain function signature type to a wrapper function pointer type |
CMethodWrapperWithSignature< R(Args...)> | |
▶NJava | |
CClass | Wrapper for a local "jclass" reference |
CFile | Wrapper for a java.io.File object |
CGlobalRef | Hold a global reference on a JNI object |
CLocalRef | Hold a local reference on a JNI object |
CObject | |
CString | Wrapper for a local "jstring" reference |
CTrivialClass | Wrapper for a global "jclass" reference |
CTrivialRef | Container for a global reference to a JNI object that gets initialised and deinitialised explicitly |
▶NPulse | |
CLockGuard | |
▶NSLES | |
CAndroidSimpleBufferQueue | OO wrapper for an OpenSL/ES SLAndroidSimpleBufferQueueItf variable |
CEngine | OO wrapper for an OpenSL/ES SLEngineItf variable |
CObject | OO wrapper for an OpenSL/ES SLObjectItf variable |
CPlay | OO wrapper for an OpenSL/ES SLPlayItf variable |
CAllocatedArray | 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 | A string pointer whose memory is managed by this class |
CArchiveFile | |
CArchivePlugin | |
CArchiveVisitor | |
CAsyncInputStream | Helper class for moving asynchronous (non-blocking) InputStream implementations to the I/O thread |
CAudioFormat | This structure describes the format of a raw PCM stream |
▶CAudioOutput | |
CRequest | Additional data for command |
CAudioOutputClient | An interface between the AudioOutput and the #Player |
CAudioOutputPlugin | A plugin which controls an audio output device |
CAudioOutputSource | Source of audio data to be played by an AudioOutput |
CAudioOutputWrapper | |
CAutoGunzipReader | A filter that detects gzip compression and optionally inserts a GunzipReader |
CAvioStream | |
CBasicStringBuffer | A statically allocated string buffer |
CBlockingNfsOperation | Utility class to implement a blocking NFS call using the libnfs async API |
CBlockParam | |
CBoundMethod | 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 | |
CBufferedSocket | A SocketMonitor specialization that adds an input buffer |
CCancellableList | |
CCancellablePointer | |
CCircularBuffer | A circular buffer |
CClient | |
CClientList | |
CClientMessage | A client-to-client message |
CCommandListBuilder | |
CCommonExpatParser | A specialization of ExpatParser that provides the most common callbacks as virtual methods |
CCompositeStorage | A Storage implementation that combines multiple other Storage instances in one virtual tree |
CCompressorConfig | Configuration values for the compressor object |
CCond | |
CConfigBlock | |
CConfigData | |
CConfigParam | |
CConfigTemplate | |
CConstBuffer | A reference to a memory area that is read-only |
CConstBuffer< void > | |
CContentDirectoryService | Content Directory Service class |
CContext | |
CCriticalSection | Wrapper for a CRITICAL_SECTION, backend for the Mutex class |
CCrossFadeSettings | |
CCueParser | |
CCurlEasy | An OO wrapper for a "CURL*" (a libCURL "easy" handle) |
CCurlGlobal | Manager for the global CURLM object |
CCurlMulti | An OO wrapper for a "CURLM*" (a libCURL "multi" handle) |
▶CCurlRequest | |
CPause | CurlResponseHandler::OnData() shall throw this to pause the stream |
CCurlResponseHandler | |
CCurlSlist | OO wrapper for "struct curl_slist *" |
CDatabase | |
CDatabaseEditor | |
CDatabaseError | |
CDatabaseListener | An object that listens to events from the Database |
CDatabasePlugin | |
CDatabaseSelection | |
CDatabaseStats | |
CDecoderBridge | A bridge between the DecoderClient interface and the MPD core (DecoderControl, MusicPipe etc.) |
CDecoderBuffer | This objects handles buffered reads in decoder plugins easily |
CDecoderClient | An interface between the decoder plugin and the MPD core |
CDecoderControl | |
CDecoderPlugin | |
CDecoderReader | A wrapper for decoder_read() which implements the Reader interface |
CDeferredCall | Invoke a method call in the EventLoop |
CDeferredMonitor | Defer execution of an event into an EventLoop |
CDeleteDisposer | A disposer for boost::intrusive that invokes the "delete" operator on the given pointer |
CDetachedSong | |
CDffDsdUint64 | |
▶CDirectory | |
CLookupResult | |
CDirectoryReader | Reader for directory entries |
CDivideString | Split a given constant string at a separator character |
CDomain | |
CDsdId | |
CDsdUint64 | |
CDynamicFifoBuffer | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CEncoder | |
CEncoderPlugin | |
CEPollFD | A class that wraps Linux epoll |
CEventFD | A class that wraps eventfd() |
CEventLoop | An event loop that polls for events on file/socket descriptors |
CEventLoopHolder | A utility class which, when used as the first base class, ensures that the EventLoop gets initialized before the other base classes |
CEventPipe | A pipe that can be used to trigger an event to the read side |
CExcludeList | |
CExpatError | |
CExpatNamespaceSeparator | |
CExpatParser | |
CFallbackPcmResampler | A naive resampler that is used when no external library was found (or when the user explicitly asks for bad quality) |
CFfmpegBuffer | |
CFileDescriptor | An OO wrapper for a UNIX file descriptor |
CFileInfo | |
CFileOutputStream | |
CFileReader | |
CFilter | |
CFilterObserver | A helper class which observes calls to a PreparedFilter and allows the caller to access the Filter instances created by it |
CFilterPlugin | |
CFlacDecoder | |
CFlacInput | This class wraps an InputStream in libFLAC stream decoder callbacks |
CFlacMetadataChain | |
CFLACMetadataIterator | |
CFlacPcmImport | This class imports libFLAC PCM data into a PCM format supported by MPD |
CFlacStreamDecoder | OO wrapper for a FLAC__StreamDecoder |
CFloatToIntegerSampleConvert | Convert from float to an integer sample format |
CForeignFifoBuffer | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CFullyBufferedSocket | A BufferedSocket specialization that adds an output buffer |
CGluePcmResampler | A glue class that integrates a PcmResampler and automatically converts source data to the sample format required by the PcmResampler instance |
CGunzipReader | A filter that decompresses data using zlib |
CGzipOutputStream | A filter that compresses data written to it using zlib, forwarding compressed data in the "gzip" format |
CHttpdClient | |
CHttpdOutput | |
CHugeAllocation | Automatic huge memory allocation management |
CIcuCompare | This class can compare one string ("needle") with lots of other strings ("haystacks") efficiently, ignoring case |
CIcyInputStream | An InputStream filter that parses Icy metadata |
CIcyMetaDataParser | |
CId3Delete | |
CIdleMonitor | An event that runs when the EventLoop has become idle, before waiting for more events |
CIdTable | A table that maps id numbers to position numbers |
CInotifyQueue | |
CInotifySource | |
CInputPlugin | |
CInputStream | |
CInputStreamReader | A Reader implementation which forwards all read calls to InputStream::Read() and logs errors |
CInstance | |
CIntegerToFloatSampleConvert | Convert from an integer sample format to float |
▶CIterableSplitString | Split a string at a certain separator character into sub strings and allow iterating over the segments |
CIterator | |
CLazyRandomEngine | A random engine that will be created and seeded on demand |
CLeftShiftSampleConvert | Convert from one integer sample format to another by shifting bits to the left |
CLibsampleratePcmResampler | A resampler using libsamplerate |
CLightDirectory | A reference to a directory |
CLightSong | A reference to a song file |
CLocatedUri | |
CManual | Container for an object that gets constructed and destructed manually |
CMaskMonitor | Manage a bit mask of events that have occurred |
CMemorySongEnumerator | |
▶CMemoryStorageDirectoryReader | A StorageDirectoryReader implementation that returns directory entries from a memory allocation |
CEntry | |
CMixer | |
CMixerListener | An interface that listens on events from mixer plugins |
CMixerPlugin | |
CMixRampInfo | |
CMultipleOutputs | |
CMultiSocketMonitor | Similar to SocketMonitor, but monitors multiple sockets |
CMusicBuffer | An allocator for MusicChunk objects |
CMusicChunk | A chunk of music data |
CMusicPipe | A queue of MusicChunk objects |
CMutex | |
CMyAvahiPoll | |
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 |
CNfsConnection | An asynchronous connection to a NFS server |
CNfsFileReader | A helper class which helps with reading from a file |
CNfsLease | |
CNfsManager | A manager for NFS connections |
Cnoise_shape_ctx_s | |
Cnotify | |
COggDecoder | |
COggEncoder | An abstract base class which contains code common to all encoders with Ogg container output |
COggStreamState | |
COggSyncState | Wrapper for an ogg_sync_state |
COggVisitor | Abstract class which iterates over Ogg packets in a Reader |
COptionDef | Command line option definition |
COptionParser | Command line option parser |
Coptions | |
COpusReader | |
COutputStream | |
CPage | A dynamically allocated buffer which keeps track of its reference count |
CPartition | A partition of the Music Player Daemon |
CPath | A path name in the native file system character set |
CPathTraitsFS | This class describes the nature of a native filesystem path |
CPathTraitsUTF8 | This class describes the nature of a MPD internal filesystem path |
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 |
CParams | |
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 |
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 |
CPeekReader | A filter that allows the caller to peek the first few bytes without consuming them |
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 | |
Cplayer_status | |
CPlayerControl | |
CPlayerListener | |
Cplaylist | |
Cplaylist_plugin | |
CPlaylistError | |
▶CPlaylistInfo | A directory entry pointing to a playlist file |
CCompareName | |
CPlaylistVector | |
CPluginUnavailable | An exception class which is used by plugin initializers to indicate that this plugin is unavailable |
CPollGroupEPoll | |
CPollGroupPoll | |
CPollGroupWinSelect | |
CPollResultEPoll | |
CPollResultGeneric | |
CPosixCond | Low-level wrapper for a pthread_cond_t |
CPosixMutex | Low-level wrapper for a pthread_mutex_t |
CPrefixedLightSong | |
CPreparedEncoder | |
CPreparedFilter | |
CProtocolError | |
CProxyInputStream | An InputStream that forwards all methods call to another InputStream instance |
▶CQueue | A queue of songs |
CItem | One element of the queue: basically a song plus some queue specific information attached |
CQueueListener | |
CRangeArg | |
CReader | An interface that can read bytes from a stream until the stream ends |
CRefCount | |
CReplayGainConfig | |
CReplayGainInfo | |
CReplayGainTuple | |
CRequest | |
CResponse | |
CReusableArray | Manager for a temporary array which grows as needed |
CRightShiftSampleConvert | Convert from one integer sample format to another by shifting bits to the right |
CSampleTraits | 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 |
CScopeExitGuard | Internal class |
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 |
CSharedPipeConsumer | A utility class which helps with consuming data from a MusicPipe |
CSignalFD | A class that wraps signalfd() |
CSignedSongTime | A variant of SongTime that is based on a signed integer |
CSimpleDatabase | |
CSliceBuffer | This class pre-allocates a certain number of objects, and allows callers to allocate and free these objects ("slices") |
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 |
CSocketSet | |
▶CSong | A song file inside the configured music directory |
CDisposer | |
CSongEnumerator | An object which provides serial access to a number of Song objects |
▶CSongFilter | |
CItem | |
CSongLoader | A utility class that loads a DetachedSong object by its URI |
CSongTime | A time stamp within a song |
CSoxrPcmResampler | A resampler using soxr |
CSqliteError | |
CStateFile | |
CStaticFifoBuffer | A first-in-first-out buffer: you can append data at the end, and read data from the beginning |
CStaticSocketAddress | An OO wrapper for struct sockaddr_storage |
CStdioOutputStream | |
CStopDecoder | Throw an instance of this class to stop decoding the current song (successfully) |
CStorage | |
CStorageDirectoryReader | |
CStorageFileInfo | |
CStoragePlugin | |
CStringBuffer | |
CStringPointer | Simple OO wrapper for a const string pointer |
CStringView | |
▶CTag | The meta information about a song file |
Cconst_iterator | |
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 |
CTagSet | A set of Tag objects |
CTextFile | |
CTextInputStream | |
CThread | |
CThreadId | A low-level identification for a thread |
CThreadInputStream | Helper class for moving InputStream implementations with blocking backend library implementation to a dedicated thread |
CTimeoutMonitor | This class monitors a timeout |
CTimer | |
CTokenizer | |
CUpdateQueue | |
CUpdateQueueItem | |
CUpdateRemoveService | This class handles Song removal |
CUpdateService | This class manages the update queue and runs the update thread |
CUpdateWalk | |
CUpnpCallback | A class that is supposed to be used for libupnp asynchronous callbacks |
CUPnPDevice | Data holder for a UPnP device, parsed from the XML description obtained during discovery |
CUPnPDeviceDirectory | Manage UPnP discovery and maintain a directory of active devices |
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 | 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 |
CWritableBuffer | A reference to a memory area that is writable |
CWritableBuffer< void > | |
CZlibError | |