namespace Poco

Overview

Namespaces: CodeGeneration, CppParser, Crypto, Data, FastInfoset, Net, Netconf, OSP, Remoting, Util, XML, Zeroconf, Zip

Classes: ASCIIEncoding, AbstractCache, AbstractDelegate, AbstractEvent, AbstractInstantiator, AbstractMetaObject, AbstractObserver, AbstractPriorityDelegate, AbstractStrategy, AbstractTimerCallback, AccessExpirationDecorator, AccessExpireCache, AccessExpireLRUCache, AccessExpireStrategy, ActiveDispatcher, ActiveMethod, ActiveResult, ActiveResultHolder, ActiveRunnable, ActiveRunnableBase, ActiveStarter, Activity, Any, ApplicationException, ArchiveByNumberStrategy, ArchiveByTimestampStrategy, ArchiveStrategy, AssertionViolationException, AsyncChannel, AutoPtr, AutoReleasePool, BadCastException, Base64Decoder, Base64DecoderBuf, Base64DecoderIOS, Base64Encoder, Base64EncoderBuf, Base64EncoderIOS, BasicBufferedBidirectionalStreamBuf, BasicBufferedStreamBuf, BasicEvent, BasicUnbufferedStreamBuf, BinaryReader, BinaryWriter, Buffer, BufferAllocator, Bugcheck, BugcheckException, ByteOrder, Channel, Checksum, CircularReferenceException, ClassLoader, Condition, Configurable, ConsoleChannel, CountingIOS, CountingInputStream, CountingOutputStream, CountingStreamBuf, CreateFileException, DataException, DataFormatException, DateTime, DateTimeFormat, DateTimeFormatter, DateTimeParser, Debugger, DefaultStrategy, DeflatingIOS, DeflatingInputStream, DeflatingOutputStream, DeflatingStreamBuf, Delegate, DigestBuf, DigestEngine, DigestIOS, DigestInputStream, DigestOutputStream, DirectoryIterator, DynamicAny, DynamicAnyHolder, DynamicAnyHolderImpl, DynamicFactory, EOFToken, Environment, ErrorHandler, Event, EventArgs, EventLogChannel, Exception, ExistsException, ExpirationDecorator, Expire, ExpireCache, ExpireLRUCache, ExpireStrategy, FIFOEvent, FIFOStrategy, FISHashTable, FPEnvironment, FastMutex, File, FileAccessDeniedException, FileChannel, FileException, FileExistsException, FileIOS, FileInputStream, FileNotFoundException, FileOutputStream, FileReadOnlyException, FileStream, FileStreamFactory, Formatter, FormattingChannel, FunctionDelegate, FunctionPriorityDelegate, Getter, Glob, HMACEngine, Hash, HashFunction, HashMap, HashMapEntry, HashMapEntryHash, HashSet, HashStatistic, HashTable, HexBinaryDecoder, HexBinaryDecoderBuf, HexBinaryDecoderIOS, HexBinaryEncoder, HexBinaryEncoderBuf, HexBinaryEncoderIOS, IOException, IllegalStateException, InflatingIOS, InflatingInputStream, InflatingOutputStream, InflatingStreamBuf, InputLineEndingConverter, InputStreamConverter, Instantiator, InvalidAccessException, InvalidArgumentException, InvalidToken, IsConst, IsReference, KeyValueArgs, LRUCache, LRUStrategy, Latin1Encoding, Latin9Encoding, LibraryAlreadyLoadedException, LibraryLoadException, LineEnding, LineEndingConverterIOS, LineEndingConverterStreamBuf, LinearHashTable, LocalDateTime, LogFile, LogIOS, LogStream, LogStreamBuf, Logger, LoggingFactory, LoggingRegistry, LogicException, MD2Engine, MD4Engine, MD5Engine, Manifest, ManifestBase, MemoryPool, Message, MetaObject, MetaSingleton, Mutex, NDCScope, NObserver, NamedEvent, NamedMutex, NamedTuple, NestedDiagnosticContext, NoPermissionException, NoThreadAvailableException, NotFoundException, NotImplementedException, Notification, NotificationCenter, NotificationQueue, NotificationStrategy, NullChannel, NullIOS, NullInputStream, NullOutputStream, NullPointerException, NullStreamBuf, NullTypeList, NumberFormatter, NumberParser, Observer, OpcomChannel, OpenFileException, OutOfMemoryException, OutputLineEndingConverter, OutputStreamConverter, Path, PathNotFoundException, PathSyntaxException, PatternFormatter, Pipe, PipeIOS, PipeInputStream, PipeOutputStream, PipeStreamBuf, PoolOverflowException, PriorityDelegate, PriorityEvent, PriorityExpire, Process, ProcessHandle, PropertyNotSupportedException, PurgeByAgeStrategy, PurgeByCountStrategy, PurgeStrategy, RWLock, Random, RandomBuf, RandomIOS, RandomInputStream, RangeException, ReadFileException, RefCountedObject, ReferenceCounter, RegularExpression, RegularExpressionException, ReleasePolicy, RotateAtTimeStrategy, RotateByIntervalStrategy, RotateBySizeStrategy, RotateStrategy, Runnable, RunnableAdapter, RuntimeException, SHA1Engine, ScopedLock, ScopedRWLock, ScopedUnlock, Semaphore, SharedLibrary, SharedMemory, SharedPtr, SignalException, SimpleFileChannel, SimpleHashTable, SingletonHolder, SplitterChannel, Stopwatch, StrategyCollection, StreamChannel, StreamConverterBuf, StreamConverterIOS, StreamCopier, StreamTokenizer, StringTokenizer, SynchronizedObject, SyntaxException, SyslogChannel, SystemException, TLSAbstractSlot, TLSSlot, Task, TaskCancelledNotification, TaskCustomNotification, TaskFailedNotification, TaskFinishedNotification, TaskManager, TaskNotification, TaskProgressNotification, TaskStartedNotification, TeeIOS, TeeInputStream, TeeOutputStream, TeeStreamBuf, TemporaryFile, TextConverter, TextEncoding, TextIterator, Thread, ThreadLocal, ThreadLocalStorage, ThreadPool, ThreadTarget, TimeoutException, Timer, TimerCallback, Timespan, Timestamp, Timezone, Token, Tuple, TypeList, TypeListType, TypeWrapper, URI, URIRedirection, URIStreamFactory, URIStreamOpener, UTF16Encoding, UTF8, UTF8Encoding, UUID, UUIDGenerator, UnhandledException, Unicode, UnicodeConverter, UniqueAccessExpireCache, UniqueAccessExpireLRUCache, UniqueAccessExpireStrategy, UniqueExpireCache, UniqueExpireLRUCache, UniqueExpireStrategy, UnknownURISchemeException, ValidArgs, Void, WhitespaceToken, Windows1252Encoding, WindowsConsoleChannel, WriteFileException, p_less

Types: BufferedBidirectionalStreamBuf, BufferedStreamBuf, FPE, Int16, Int32, Int64, Int8, IntPtr, NDC, UInt16, UInt32, UInt64, UInt8, UIntPtr, UnbufferedStreamBuf

Functions: AnyCast, RefAnyCast, UnsafeAnyCast, cat, delegate, format, hash, icompare, operator, operator !=, operator *, operator *=, operator +, operator +=, operator -, operator -=, operator /, operator /=, operator <, operator <=, operator >, operator >=, priorityDelegate, replace, replaceInPlace, swap, toLower, toLowerInPlace, toUpper, toUpperInPlace, translate, translateInPlace, trim, trimInPlace, trimLeft, trimLeftInPlace, trimRight, trimRightInPlace

Namespaces

namespace CodeGeneration

namespace CppParser

namespace Crypto

namespace Data

namespace FastInfoset

namespace Net

namespace Netconf

namespace OSP

namespace Remoting

namespace Util

namespace XML

namespace Zeroconf

namespace Zip

Classes

class ASCIIEncoding

7-bit ASCII text encoding. more...

class AbstractCache

An AbstractCache is the interface of all caches. more...

class AbstractDelegate

Interface for Delegate and Expire Very similar to AbstractPriorityDelegate but having two separate files (no inheritance) allows one to have compile-time checks when registering an observer instead of run-time checks. more...

class AbstractEvent

An AbstractEvent is the super-class of all events. more...

class AbstractInstantiator

The common base class for all Instantiator instantiations. more...

class AbstractMetaObject

A MetaObject stores some information about a C++ class. more...

class AbstractObserver

The base class for all instantiations of the Observer and NObserver template classes. more...

class AbstractPriorityDelegate

Interface for PriorityDelegate and PriorityExpiremore...

class AbstractStrategy

An AbstractStrategy is the interface for all strategies. more...

class AbstractTimerCallback

This is the base class for all instantiations of the TimerCallback template. more...

class AccessExpirationDecorator

AccessExpirationDecorator adds an expiration method to values so that they can be used with the UniqueAccessExpireCache more...

class AccessExpireCache

An AccessExpireCache caches entries for a fixed time period (per default 10 minutes). more...

class AccessExpireLRUCache

An AccessExpireLRUCache combines LRU caching and time based expire caching. more...

class AccessExpireStrategy

An AccessExpireStrategy implements time and access based expiration of cache entries more...

class ActiveDispatcher

This class is used to implement an active object with strictly serialized method execution. more...

class ActiveMethod

An active method is a method that, when called, executes in its own thread. more...

class ActiveResult

Creates an ActiveResultHoldermore...

class ActiveResultHolder

This class holds the result of an asynchronous method invocation. more...

class ActiveRunnable

This class is used by ActiveMethodmore...

class ActiveRunnableBase

The base class for all ActiveRunnable instantiations. more...

class ActiveStarter

The default implementation of the StarterType policy for ActiveMethodmore...

class Activity

This template class helps to implement active objects. more...

class Any

An Any class represents a general type and is capable of storing any type, supporting type-safe extraction of the internally stored data. more...

class ApplicationException

 more...

class ArchiveByNumberStrategy

A monotonic increasing number is appended to the log file name. more...

class ArchiveByTimestampStrategy

A timestamp (YYYYMMDDhhmmssiii) is appended to archived log files. more...

class ArchiveStrategy

The ArchiveStrategy is used by FileChannel to rename a rotated log file for archiving. more...

class AssertionViolationException

 more...

class AsyncChannel

A channel uses a separate thread for logging. more...

class AutoPtr

AutoPtr is a "smart" pointer for classes implementing reference counting based garbage collection. more...

class AutoReleasePool

An AutoReleasePool implements simple garbage collection for reference-counted objects. more...

class BadCastException

 more...

class Base64Decoder

This istream base64-decodes all data read from the istream connected to it. more...

class Base64DecoderBuf

This streambuf base64-decodes all data read from the istream connected to it. more...

class Base64DecoderIOS

The base class for Base64Decodermore...

class Base64Encoder

This ostream base64-encodes all data written to it and forwards it to a connected ostream. more...

class Base64EncoderBuf

This streambuf base64-encodes all data written to it and forwards it to a connected ostream. more...

class Base64EncoderIOS

The base class for Base64Encodermore...

class BasicBufferedBidirectionalStreamBuf

This is an implementation of a buffered bidirectional streambuf that greatly simplifies the implementation of custom streambufs of various kinds. more...

class BasicBufferedStreamBuf

This is an implementation of a buffered streambuf that greatly simplifies the implementation of custom streambufs of various kinds. more...

class BasicEvent

A BasicEvent uses internally a DefaultStrategy which invokes delegates in an arbitrary manner. more...

class BasicUnbufferedStreamBuf

This is an implementation of an unbuffered streambuf that greatly simplifies the implementation of custom streambufs of various kinds. more...

class BinaryReader

This class reads basic types in binary form into an input stream. more...

class BinaryWriter

This class writes basic types in binary form into an output stream. more...

class Buffer

A very simple buffer class that allocates a buffer of a given type and size in the constructor and deallocates the buffer in the destructor. more...

class BufferAllocator

The BufferAllocator used if no specific BufferAllocator has been specified. more...

class Bugcheck

This class provides some static methods that are used by the poco_assert_dbg(), poco_assert(), poco_check_ptr() and poco_bugcheck() macros. more...

class BugcheckException

 more...

class ByteOrder

This class contains a number of static methods to convert between big-endian and little-endian integers of various sizes. more...

class Channel

The base class for all Channel classes. more...

class Checksum

This class calculates CRC-32 or Adler-32 checksums for arbitrary data. more...

class CircularReferenceException

 more...

class ClassLoader

The ClassLoader loads C++ classes from shared libraries at runtime. more...

class Condition

A Condition is a synchronization object used to block a thread until a particular condition is met. more...

class Configurable

A simple interface that defines getProperty() and setProperty() methods. more...

class ConsoleChannel

A channel that writes to an ostream. more...

class CountingIOS

The base class for CountingInputStream and CountingOutputStreammore...

class CountingInputStream

This stream counts all characters and lines going through it. more...

class CountingOutputStream

This stream counts all characters and lines going through it. more...

class CountingStreamBuf

This stream buffer counts all characters and lines going through it. more...

class CreateFileException

 more...

class DataException

 more...

class DataFormatException

 more...

class DateTime

This class represents an instant in time, expressed in years, months, days, hours, minutes, seconds and milliseconds based on the Gregorian calendar. more...

class DateTimeFormat

Definition of date/time formats and various constants used by DateTimeFormatter and DateTimeParsermore...

class DateTimeFormatter

This class converts dates and times into strings, supporting a variety of standard and custom formats. more...

class DateTimeParser

This class provides a method for parsing dates and times from strings. more...

class Debugger

The Debugger class provides an interface to the debugger. more...

class DefaultStrategy

Default notification strategy. more...

class DeflatingIOS

The base class for DeflatingOutputStream and DeflatingInputStreammore...

class DeflatingInputStream

This stream compresses all data passing through it using zlib's deflate algorithm. more...

class DeflatingOutputStream

This stream compresses all data passing through it using zlib's deflate algorithm. more...

class DeflatingStreamBuf

This is the streambuf class used by DeflatingInputStream and DeflatingOutputStreammore...

class Delegate

 more...

class DigestBuf

This streambuf computes a digest of all data going through it. more...

class DigestEngine

This class is an abstract base class for all classes implementing a message digest algorithm, like MD5Engine and SHA1Enginemore...

class DigestIOS

The base class for DigestInputStream and DigestOutputStreammore...

class DigestInputStream

This istream computes a digest of all the data passing through it, using a DigestEnginemore...

class DigestOutputStream

This ostream computes a digest of all the data passing through it, using a DigestEnginemore...

class DirectoryIterator

The DirectoryIterator class is used to enumerate all files in a directory. more...

class DynamicAny

DynamicAny allows to store data of different types and to convert between these types transparently. more...

class DynamicAnyHolder

Interface for a data holder used by the DynamicAny class. more...

class DynamicAnyHolderImpl

Template based implementation of a DynamicAnyHoldermore...

class DynamicFactory

A factory that creates objects by class name. more...

class EOFToken

This token class is used to signal the end of the input stream. more...

class Environment

This class provides access to environment variables and some general system information. more...

class ErrorHandler

This is the base class for thread error handlers. more...

class Event

An Event is a synchronization object that allows one thread to signal one or more other threads that a certain event has happened. more...

class EventArgs

The purpose of the EventArgs class is to be used as parameter when one doesn't want to send any data. more...

class EventLogChannel

This Windows-only channel works with the Windows NT Event Log service. more...

class Exception

This is the base class for all exceptions defined in the Poco class library. more...

class ExistsException

 more...

class ExpirationDecorator

ExpirationDecorator adds an expiration method to values so that they can be used with the UniqueExpireCache more...

class Expire

Decorator for AbstractDelegate adding automatic expiring of registrations to AbstractDelegates. more...

class ExpireCache

An ExpireCache caches entries for a fixed time period (per default 10 minutes). more...

class ExpireLRUCache

An ExpireLRUCache combines LRU caching and time based expire caching. more...

class ExpireStrategy

An ExpireStrategy implements time based expiration of cache entries more...

class FIFOEvent

A FIFOEvent uses internally a FIFOStrategy which guarantees that delegates are invoked in the order they were added to the event. more...

class FIFOStrategy

 more...

class FISHashTable

A FISHashTable stores a key value pair that can be looked up via a hashed key. more...

class FPEnvironment

Instances of this class can be used to save and later restore the current floating point environment (consisting of rounding mode and floating-point flags). more...

class FastMutex

A FastMutex (mutual exclusion) is similar to a Mutexmore...

class File

The File class provides methods for working with a file. more...

class FileAccessDeniedException

 more...

class FileChannel

A Channel that writes to a file. more...

class FileException

 more...

class FileExistsException

 more...

class FileIOS

The base class for FileInputStream and FileOutputStreammore...

class FileInputStream

An input stream for reading from a file. more...

class FileNotFoundException

 more...

class FileOutputStream

An output stream for writing to a file. more...

class FileReadOnlyException

 more...

class FileStream

A stream for reading from and writing to a file. more...

class FileStreamFactory

An implementation of the URIStreamFactory interface that handles file URIs. more...

class Formatter

The base class for all Formatter classes. more...

class FormattingChannel

The FormattingChannel is a filter channel that routes a Message through a Formatter before passing it on to the destination channel. more...

class FunctionDelegate

Wraps a C style function (or a C++ static fucntion) to be used as a delegate more...

class FunctionPriorityDelegate

Wraps a C style function (or a C++ static fucntion) to be used as a priority delegate more...

struct Getter

 more...

class Glob

This class implements glob-style pattern matching as known from Unix shells. more...

class HMACEngine

This class implementes the HMAC message authentication code algorithm, as specified in RFC 2104more...

struct Hash

A generic hash function. more...

struct HashFunction

A generic hash function. more...

class HashMap

This class implements a map using a LinearHashTablemore...

struct HashMapEntry

This class template is used internally by HashMapmore...

struct HashMapEntryHash

This class template is used internally by HashMapmore...

class HashSet

This class implements a set using a LinearHashTablemore...

class HashStatistic

HashStatistic class bundles statistical information on the current state of a HashTable more...

class HashTable

A HashTable stores a key value pair that can be looked up via a hashed key. more...

class HexBinaryDecoder

This istream decodes all hexBinary-encoded data read from the istream connected to it. more...

class HexBinaryDecoderBuf

This streambuf decodes all hexBinary-encoded data read from the istream connected to it. more...

class HexBinaryDecoderIOS

The base class for HexBinaryDecodermore...

class HexBinaryEncoder

This ostream encodes all data written to it in BinHex encoding and forwards it to a connected ostream. more...

class HexBinaryEncoderBuf

This streambuf encodes all data written to it in hexBinary encoding and forwards it to a connected ostream. more...

class HexBinaryEncoderIOS

The base class for HexBinaryEncodermore...

class IOException

 more...

class IllegalStateException

 more...

class InflatingIOS

The base class for InflatingOutputStream and InflatingInputStreammore...

class InflatingInputStream

This stream decompresses all data passing through it using zlib's inflate algorithm. more...

class InflatingOutputStream

This stream decompresses all data passing through it using zlib's inflate algorithm. more...

class InflatingStreamBuf

This is the streambuf class used by InflatingInputStream and InflatingOutputStreammore...

class InputLineEndingConverter

InputLineEndingConverter performs line ending conversion on text input streams. more...

class InputStreamConverter

This stream converts all characters read from the underlying istream from one character encoding into another. more...

class Instantiator

A template class for the easy instantiation of instantiators. more...

class InvalidAccessException

 more...

class InvalidArgumentException

 more...

class InvalidToken

This token class is used for signalling that an invalid character sequence has been encountered in the input stream. more...

struct IsConst

Use this struct to determine if a template type is a const type more...

struct IsReference

Use this struct to determine if a template type is a reference more...

class KeyValueArgs

Simply event arguments class to transfer a key and a value via an event call. more...

class LRUCache

An LRUCache implements Least Recently Used caching. more...

class LRUStrategy

An LRUStrategy implements least recently used cache replacement. more...

class Latin1Encoding

ISO Latin-1 (8859-1) text encoding. more...

class Latin9Encoding

ISO Latin-9 (8859-15) text encoding. more...

class LibraryAlreadyLoadedException

 more...

class LibraryLoadException

 more...

class LineEnding

This class defines valid line ending sequences for InputLineEndingConverter and OutputLineEndingConvertermore...

class LineEndingConverterIOS

The base class for InputLineEndingConverter and OutputLineEndingConvertermore...

class LineEndingConverterStreamBuf

This stream buffer performs line ending conversion on text streams. more...

class LinearHashTable

This class implements a linear hash table. more...

class LocalDateTime

This class represents an instant in local time (as opposed to UTC), expressed in years, months, days, hours, minutes, seconds and milliseconds based on the Gregorian calendar. more...

class LogFile

This class is used by FileChannel to work with a log file. more...

class LogIOS

The base class for LogStreammore...

class LogStream

This class implements an ostream interface to a Loggermore...

class LogStreamBuf

This class implements a streambuf interface to a Loggermore...

class Logger

Logger is a special Channel that acts as the main entry point into the logging framework. more...

class LoggingFactory

An extensible factory for channels and formatters. more...

class LoggingRegistry

A registry for channels and formatters. more...

class LogicException

 more...

class MD2Engine

This class implementes the MD2 message digest algorithm, described in RFC 1319more...

class MD4Engine

This class implementes the MD4 message digest algorithm, described in RFC 1320more...

class MD5Engine

This class implementes the MD5 message digest algorithm, described in RFC 1321more...

class Manifest

A Manifest maintains a list of all classes contained in a dynamically loadable class library. more...

class ManifestBase

ManifestBase is a common base class for all instantiations of Manifestmore...

class MemoryPool

A simple pool for fixed-size memory blocks. more...

class Message

This class represents a log message that is sent through a chain of log channels. more...

class MetaObject

A MetaObject stores some information about a C++ class. more...

class MetaSingleton

A SingletonMetaObject disables the create() method and instead offers an instance() method to access the single instance of its class. more...

class Mutex

A Mutex (mutual exclusion) is a synchronization mechanism used to control access to a shared resource in a concurrent (multithreaded) scenario. more...

class NDCScope

This class can be used to automatically push a context onto the NDC stack at the beginning of a scope, and to pop the context at the end of the scope. more...

class NObserver

This template class implements an adapter that sits between a NotificationCenter and an object receiving notifications from it. more...

class NamedEvent

An NamedEvent is a global synchronization object that allows one process or thread to signal an other process or thread that a certain event has happened. more...

class NamedMutex

A NamedMutex (mutual exclusion) is a global synchronization mechanism used to control access to a shared resource in a concurrent (multi process) scenario. more...

struct NamedTuple

 more...

class NestedDiagnosticContext

This class implements a Nested Diagnostic Context (NDC), as described in Neil Harrison's article "Patterns for Logging Diagnostic Messages" in "Pattern Languages of Program Design 3" (Addison-Wesley). more...

class NoPermissionException

 more...

class NoThreadAvailableException

 more...

class NotFoundException

 more...

class NotImplementedException

 more...

class Notification

The base class for all notification classes used with the NotificationCenter and the NotificationQueue classes. more...

class NotificationCenter

A NotificationCenter is essentially a notification dispatcher. more...

class NotificationQueue

A NotificationQueue object provides a way to implement asynchronous notifications. more...

class NotificationStrategy

The interface that all notification strategies must implement. more...

class NullChannel

The NullChannel is the /dev/null of Channels. more...

class NullIOS

The base class for NullInputStream and NullOutputStreammore...

class NullInputStream

Any read operation from this stream immediately yields EOF. more...

class NullOutputStream

This stream discards all characters written to it. more...

class NullPointerException

 more...

class NullStreamBuf

This stream buffer discards all characters written to it. more...

struct NullTypeList

 more...

class NumberFormatter

The NumberFormatter class provides static methods for formatting numeric values into strings. more...

class NumberParser

The NumberParser class provides static methods for parsing numbers out of strings. more...

class Observer

This template class implements an adapter that sits between a NotificationCenter and an object receiving notifications from it. more...

class OpcomChannel

A OpenVMS-only channel that uses the OpenVMS OPCOM service. more...

class OpenFileException

 more...

class OutOfMemoryException

 more...

class OutputLineEndingConverter

OutputLineEndingConverter performs line ending conversion on text output streams. more...

class OutputStreamConverter

This stream converts all characters written to the underlying ostream from one character encoding into another. more...

class Path

This class represents filesystem paths in a platform-independent manner. more...

class PathNotFoundException

 more...

class PathSyntaxException

 more...

class PatternFormatter

This Formatter allows for custom formatting of log messages based on format patterns. more...

class Pipe

This class implements an anonymous pipe. more...

class PipeIOS

The base class for PipeInputStream and PipeOutputStreammore...

class PipeInputStream

An input stream for reading from a Pipemore...

class PipeOutputStream

An output stream for writing to a Pipemore...

class PipeStreamBuf

This is the streambuf class used for reading from and writing to a Pipemore...

class PoolOverflowException

 more...

class PriorityDelegate

 more...

class PriorityEvent

A PriorityEvent uses internally a DefaultStrategy which invokes delegates in a manner determined by the priority field in the PriorityDelegates (lower priorities first). more...

class PriorityExpire

Decorator for AbstractPriorityDelegate adding automatic expiring of registrations to AbstractPriorityDelegatemore...

class Process

This class provides methods for working with processes. more...

class ProcessHandle

A handle for a process created with Process::launch(). more...

class PropertyNotSupportedException

 more...

class PurgeByAgeStrategy

This purge strategy purges all files that have exceeded a given age (given in seconds). more...

class PurgeByCountStrategy

This purge strategy ensures that a maximum number of archived files is not exceeded. more...

class PurgeStrategy

The PurgeStrategy is used by FileChannel to purge archived log files. more...

class RWLock

A reader writer lock allows multiple concurrent readers or one exclusive writer. more...

class Random

A better random number generator. more...

class RandomBuf

This streambuf generates random data. more...

class RandomIOS

The base class for RandomInputStreammore...

class RandomInputStream

This istream generates random data using the RandomBufmore...

class RangeException

 more...

class ReadFileException

 more...

class RefCountedObject

A base class for objects that employ reference counting based garbage collection. more...

class ReferenceCounter

Simple ReferenceCounter object, does not delete itself when count reaches 0. more...

class RegularExpression

A class for working with regular expressions. more...

class RegularExpressionException

 more...

class ReleasePolicy

The default release policy for SharedPtr, which simply uses the delete operator to delete an object. more...

class RotateAtTimeStrategy

The file is rotated at specified [day,][hour]:minute more...

class RotateByIntervalStrategy

The file is rotated when the log file exceeds a given age. more...

class RotateBySizeStrategy

The file is rotated when the log file exceeds a given size. more...

class RotateStrategy

The RotateStrategy is used by LogFile to determine when a file must be rotated. more...

class Runnable

The Runnable interface with the run() method must be implemented by classes that provide an entry point for a thread. more...

class RunnableAdapter

This adapter simplifies using ordinary methods as targets for threads. more...

class RuntimeException

 more...

class SHA1Engine

This class implementes the SHA-1 message digest algorithm. more...

class ScopedLock

A class that simplifies thread synchronization with a mutex. more...

class ScopedRWLock

A variant of ScopedLock for reader/writer locks. more...

class ScopedUnlock

A class that simplifies thread synchronization with a mutex. more...

class Semaphore

A Semaphore is a synchronization object with the following characteristics: A semaphore has a value that is constrained to be a non-negative integer and two atomic operations. more...

class SharedLibrary

The SharedLibrary class dynamically loads shared libraries at run-time. more...

class SharedMemory

Create and manage a shared memory object. more...

class SharedPtr

SharedPtr is a "smart" pointer for classes implementing reference counting based garbage collection. more...

class SignalException

 more...

class SimpleFileChannel

A Channel that writes to a file. more...

class SimpleHashTable

A SimpleHashTable stores a key value pair that can be looked up via a hashed key. more...

class SingletonHolder

This is a helper template class for managing singleton objects allocated on the heap. more...

class SplitterChannel

This channel sends a message to multiple channels simultaneously. more...

class Stopwatch

A simple facility to measure time intervals with microsecond resolution. more...

class StrategyCollection

An StrategyCollection is a decorator masking n collections as a single one more...

class StreamChannel

A channel that writes to an ostream. more...

class StreamConverterBuf

A StreamConverter converts streams from one encoding (inEncoding) into another (outEncoding). more...

class StreamConverterIOS

The base class for InputStreamConverter and OutputStreamConvertermore...

class StreamCopier

This class provides static methods to copy the contents from one stream into another. more...

class StreamTokenizer

A stream tokenizer splits an input stream into a sequence of tokens of different kinds. more...

class StringTokenizer

A simple tokenizer that splits a string into tokens, which are separated by separator characters. more...

class SynchronizedObject

This class aggregates a Mutex and an Event and can act as a base class for all objects requiring synchronization in a multithreaded scenario. more...

class SyntaxException

 more...

class SyslogChannel

This Unix-only channel works with the Unix syslog service. more...

class SystemException

 more...

class TLSAbstractSlot

This is the base class for all objects that the ThreadLocalStorage class manages. more...

class TLSSlot

The Slot template wraps another class so that it can be stored in a ThreadLocalStorage object. more...

class Task

A Task is a subclass of Runnable that has a name and supports progress reporting and cancellation. more...

class TaskCancelledNotification

This notification is posted by the TaskManager for every task that has been cancelled. more...

class TaskCustomNotification

This is a template for "custom" notification. more...

class TaskFailedNotification

This notification is posted by the TaskManager for every task that has failed with an exception. more...

class TaskFinishedNotification

This notification is posted by the TaskManager for every task that has finished. more...

class TaskManager

The TaskManager manages a collection of tasks and monitors their lifetime. more...

class TaskNotification

Base class for TaskManager notifications. more...

class TaskProgressNotification

This notification is posted by the TaskManager for every task that has failed with an exception. more...

class TaskStartedNotification

This notification is posted by the TaskManager for every task that has been started. more...

class TeeIOS

The base class for TeeInputStream and TeeOutputStreammore...

class TeeInputStream

This stream copies all characters read through it to one or multiple output streams. more...

class TeeOutputStream

This stream copies all characters written to it to one or multiple output streams. more...

class TeeStreamBuf

This stream buffer copies all data written to or read from it to one or multiple output streams. more...

class TemporaryFile

The TemporaryFile class helps with the handling of temporary files. more...

class TextConverter

A TextConverter converts strings from one encoding into another. more...

class TextEncoding

An abstract base class for implementing text encodings like UTF-8 or ISO 8859-1. more...

class TextIterator

An unidirectional iterator for iterating over characters in a string. more...

class Thread

This class implements a platform-independent wrapper to an operating system thread. more...

class ThreadLocal

This template is used to declare type safe thread local variables. more...

class ThreadLocalStorage

This class manages the local storage for each thread. more...

class ThreadPool

A thread pool always keeps a number of threads running, ready to accept work. more...

class ThreadTarget

This adapter simplifies using static member functions as well as standalone functions as targets for threads. more...

class TimeoutException

 more...

class Timer

This class implements a thread-based timer. more...

class TimerCallback

This template class implements an adapter that sits between a Timer and an object's method invoked by the timer. more...

class Timespan

A class that represents time spans up to microsecond resolution. more...

class Timestamp

A Timestamp stores a monotonic time value with (theoretical) microseconds resolution. more...

class Timezone

This class provides information about the current timezone. more...

class Token

The base class for all token classes that can be registered with the StreamTokenizermore...

struct Tuple

 more...

struct TypeList

Compile Time List of Types more...

struct TypeListType

TypeListType takes 1 - 20 typename arguments. more...

struct TypeWrapper

Use the type wrapper if you want to dedecouple constness and references from template types more...

class URI

A Uniform Resource Identifier, as specified in RFC 3986more...

class URIRedirection

An instance of URIRedirection is thrown by a URIStreamFactory::open() if opening the original URI resulted in a redirection response (such as a MOVED PERMANENTLY in HTTP). more...

class URIStreamFactory

This class defines the interface that all URI stream factories must implement. more...

class URIStreamOpener

The URIStreamOpener class is used to create and open input streams for resourced identified by Uniform Resource Identifiers. more...

class UTF16Encoding

UTF-16 text encoding, as defined in RFC 2781more...

struct UTF8

This class provides static methods that are UTF-8 capable variants of the same functions in Poco/String. more...

class UTF8Encoding

UTF-8 text encoding, as defined in RFC 2279more...

class UUID

A UUID is an identifier that is unique across both space and time, with respect to the space of all UUIDs. more...

class UUIDGenerator

This class implements a generator for Universal Unique Identifiers, as specified in Appendix A of the DCE 1. more...

class UnhandledException

 more...

class Unicode

This class contains enumerations and static utility functions for dealing with Unicode characters and their properties. more...

class UnicodeConverter

A convenience class that converts strings from UTF-8 encoded std::strings to UTF-16 encoded std::wstrings and vice-versa. more...

class UniqueAccessExpireCache

An UniqueAccessExpireCache caches entries for a given time span. more...

class UniqueAccessExpireLRUCache

A UniqueAccessExpireLRUCache combines LRU caching and time based per entry expire caching. more...

class UniqueAccessExpireStrategy

An UniqueExpireStrategy implements time based expiration of cache entries. more...

class UniqueExpireCache

An UniqueExpireCache caches entries for a given time amount. more...

class UniqueExpireLRUCache

A UniqueExpireLRUCache combines LRU caching and time based per entry expire caching. more...

class UniqueExpireStrategy

An UniqueExpireStrategy implements time based expiration of cache entries. more...

class UnknownURISchemeException

 more...

class ValidArgs

 more...

class Void

A dummy class with value-type semantics, mostly useful as a template argument. more...

class WhitespaceToken

This pseudo token class is used to eat up whitespace in between real tokens. more...

class Windows1252Encoding

Windows Codepage 1252 text encoding. more...

class WindowsConsoleChannel

A channel that writes to the Windows console. more...

class WriteFileException

 more...

struct p_less

 more...

Types

BufferedBidirectionalStreamBuf

typedef BasicBufferedBidirectionalStreamBuf < char, std::char_traits < char > > BufferedBidirectionalStreamBuf;

BufferedStreamBuf

typedef BasicBufferedStreamBuf < char, std::char_traits < char > > BufferedStreamBuf;

FPE

typedef FPEnvironment FPE;

Int16

typedef signed short Int16;

Int32

typedef signed int Int32;

Int64

typedef signed __int64 Int64;

Int8

typedef signed char Int8;

IntPtr

typedef signed long IntPtr;

NDC

typedef NestedDiagnosticContext NDC;

UInt16

typedef unsigned short UInt16;

UInt32

typedef unsigned int UInt32;

UInt64

typedef unsigned __int64 UInt64;

UInt8

typedef unsigned char UInt8;

UIntPtr

typedef unsigned long UIntPtr;

UnbufferedStreamBuf

typedef BasicUnbufferedStreamBuf < char, std::char_traits < char > > UnbufferedStreamBuf;

Functions

AnyCast inline

template < typename ValueType > ValueType * AnyCast(
    Any * operand
);

AnyCast operator used to extract the ValueType from an Any*. Will return a pointer to the stored value.

Example Usage:

MyType* pTmp = AnyCast<MyType*>(pAny).

Will return NULL if the cast fails, i.e. types don't match.

AnyCast inline

template < typename ValueType > const ValueType * AnyCast(
    const Any * operand
);

AnyCast operator used to extract a const ValueType pointer from an const Any*. Will return a const pointer to the stored value.

Example Usage:

const MyType* pTmp = AnyCast<MyType*>(pAny).

Will return NULL if the cast fails, i.e. types don't match.

AnyCast inline

template < typename ValueType > ValueType AnyCast(
    const Any & operand
);

AnyCast operator used to extract a copy of the ValueType from an const Any&.

Example Usage:

MyType tmp = AnyCast<MyType>(anAny).

Will throw a BadCastException if the cast fails. Dont use an AnyCast in combination with references, i.e. MyType& tmp = ... or const MyType& = ... Some compilers will accept this code although a copy is returned. Use the RefAnyCast in these cases.

AnyCast inline

template < typename ValueType > ValueType AnyCast(
    Any & operand
);

AnyCast operator used to extract a copy of the ValueType from an Any&.

Example Usage:

MyType tmp = AnyCast<MyType>(anAny).

Will throw a BadCastException if the cast fails. Dont use an AnyCast in combination with references, i.e. MyType& tmp = ... or const MyType& tmp = ... Some compilers will accept this code although a copy is returned. Use the RefAnyCast in these cases.

RefAnyCast inline

template < typename ValueType > const ValueType & RefAnyCast(
    const Any & operand
);

AnyCast operator used to return a const reference to the internal data.

Example Usage:

const MyType& tmp = RefAnyCast<MyType>(anAny);

RefAnyCast inline

template < typename ValueType > ValueType & RefAnyCast(
    Any & operand
);

AnyCast operator used to return a reference to the internal data.

Example Usage:

MyType& tmp = RefAnyCast<MyType>(anAny);

UnsafeAnyCast inline

template < typename ValueType > ValueType * UnsafeAnyCast(
    Any * operand
);

The "unsafe" versions of AnyCast are not part of the public interface and may be removed at any time. They are required where we know what type is stored in the any and can't use typeid() comparison, e.g., when our types may travel across different shared libraries.

UnsafeAnyCast inline

template < typename ValueType > const ValueType * UnsafeAnyCast(
    const Any * operand
);

The "unsafe" versions of AnyCast are not part of the public interface and may be removed at any time. They are required where we know what type is stored in the any and can't use typeid() comparison, e.g., when our types may travel across different shared libraries.

cat inline

template < class S > S cat(
    const S & s1,
    const S & s2
);

Concatenates two strings.

cat inline

template < class S > S cat(
    const S & s1,
    const S & s2,
    const S & s3
);

Concatenates three strings.

cat inline

template < class S > S cat(
    const S & s1,
    const S & s2,
    const S & s3,
    const S & s4
);

Concatenates four strings.

cat inline

template < class S > S cat(
    const S & s1,
    const S & s2,
    const S & s3,
    const S & s4,
    const S & s5
);

Concatenates five strings.

cat inline

template < class S > S cat(
    const S & s1,
    const S & s2,
    const S & s3,
    const S & s4,
    const S & s5,
    const S & s6
);

Concatenates six strings.

cat inline

template < class S, class It > S cat(
    const S & delim,
    const It & begin,
    const It & end
);

Concatenates a sequence of strings, delimited by the string given in delim.

delegate static inline

template < class TObj, class TArgs > static Delegate < TObj, TArgs, true > delegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(const void *, TArgs &) param95
);

delegate static inline

template < class TObj, class TArgs > static Delegate < TObj, TArgs, false > delegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(TArgs &) param96
);

delegate static inline

template < class TObj, class TArgs > static Expire < TArgs > delegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(const void *, TArgs &) param97,
    Timestamp::TimeDiff expireMillisecs
);

delegate static inline

template < class TObj, class TArgs > static Expire < TArgs > delegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(TArgs &) param98,
    Timestamp::TimeDiff expireMillisecs
);

delegate static inline

template < class TArgs > static Expire < TArgs > delegate(
    void (* NotifyMethod)(const void *, TArgs &) param99,
    Timestamp::TimeDiff expireMillisecs
);

delegate static inline

template < class TArgs > static Expire < TArgs > delegate(
    void (* NotifyMethod)(void *, TArgs &) param100,
    Timestamp::TimeDiff expireMillisecs
);

delegate static inline

template < class TArgs > static Expire < TArgs > delegate(
    void (* NotifyMethod)(TArgs &) param101,
    Timestamp::TimeDiff expireMillisecs
);

delegate static inline

template < class TArgs > static FunctionDelegate < TArgs, true, true > delegate(
    void (* NotifyMethod)(const void *, TArgs &) param102
);

delegate static inline

template < class TArgs > static FunctionDelegate < TArgs, true, false > delegate(
    void (* NotifyMethod)(void *, TArgs &) param103
);

delegate static inline

template < class TArgs > static FunctionDelegate < TArgs, false > delegate(
    void (* NotifyMethod)(TArgs &) param104
);

format

std::string format(
    const std::string & fmt,
    const Any & value
);

This function implements sprintf-style formatting in a typesafe way. Various variants of the function are available, supporting a different number of arguments (up to six).

The formatting is controlled by the format string in fmt. Format strings are quite similar to those of the std::printf() function, but there are some minor differences.

The format string can consist of any sequence of characters; certain characters have a special meaning. Characters without a special meaning are copied verbatim to the result. A percent sign (%) marks the beginning of a format specification. Format specifications have the following syntax:

%[<flags>][<width>][.<precision>][<modifier>]<type>

Flags, width, precision and prefix are optional. The only required part of the format specification, apart from the percent sign, is the type.

Following are valid type specifications and their meaning:

The following flags are supported:

The following modifiers are supported:

The width argument is a nonnegative decimal integer controlling the minimum number of characters printed. If the number of characters in the output value is less than the specified width, blanks or leading zeros are added, according to the specified flags (-, +, 0).

Precision is a nonnegative decimal integer, preceded by a period (.), which specifies the number of characters to be printed, the number of decimal places, or the number of significant digits.

Throws a BadCastException if an argument does not correspond to the type of its format specification.

If there are more format specifiers than values, the format specifiers without a corresponding value are copied verbatim to output.

If there are more values than format specifiers, the superfluous values are ignored.

Usage Example:

std::string s = format("The answer to life, the universe, and everything is %d", 42);

format

std::string format(
    const std::string & fmt,
    const Any & value1,
    const Any & value2
);

format

std::string format(
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3
);

format

std::string format(
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4
);

format

std::string format(
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4,
    const Any & value5
);

format

std::string format(
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4,
    const Any & value5,
    const Any & value6
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value
);

Appends the formatted string to result.

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value1,
    const Any & value2
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4,
    const Any & value5
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const Any & value1,
    const Any & value2,
    const Any & value3,
    const Any & value4,
    const Any & value5,
    const Any & value6
);

format

void format(
    std::string & result,
    const std::string & fmt,
    const std::vector < Any > & values
);

Supports a variable number of arguments and is used by all other variants of format().

hash

std::size_t hash(
    Int8 n
);

hash

std::size_t hash(
    UInt8 n
);

hash

std::size_t hash(
    Int16 n
);

hash

std::size_t hash(
    UInt16 n
);

hash

std::size_t hash(
    Int32 n
);

hash

std::size_t hash(
    UInt32 n
);

hash

std::size_t hash(
    Int64 n
);

hash

std::size_t hash(
    UInt64 n
);

hash

std::size_t hash(
    const std::string & str
);

hash inline

inline std::size_t hash(
    Int8 n
);

hash inline

inline std::size_t hash(
    UInt8 n
);

hash inline

inline std::size_t hash(
    Int16 n
);

hash inline

inline std::size_t hash(
    UInt16 n
);

hash inline

inline std::size_t hash(
    Int32 n
);

hash inline

inline std::size_t hash(
    UInt32 n
);

hash inline

inline std::size_t hash(
    Int64 n
);

hash inline

inline std::size_t hash(
    UInt64 n
);

icompare inline

template < class S, class It > int icompare(
    const S & str,
    typename S::size_type pos,
    typename S::size_type n,
    It it2,
    It end2
);

Case-insensitive string comparison

icompare inline

template < class S > int icompare(
    const S & str1,
    const S & str2
);

icompare inline

template < class S > int icompare(
    const S & str1,
    typename S::size_type n1,
    const S & str2,
    typename S::size_type n2
);

icompare inline

template < class S > int icompare(
    const S & str1,
    typename S::size_type n,
    const S & str2
);

icompare inline

template < class S > int icompare(
    const S & str1,
    typename S::size_type pos,
    typename S::size_type n,
    const S & str2
);

icompare inline

template < class S > int icompare(
    const S & str1,
    typename S::size_type pos1,
    typename S::size_type n1,
    const S & str2,
    typename S::size_type pos2,
    typename S::size_type n2
);

icompare inline

template < class S > int icompare(
    const S & str1,
    typename S::size_type pos1,
    typename S::size_type n,
    const S & str2,
    typename S::size_type pos2
);

icompare inline

template < class S > int icompare(
    const S & str,
    typename S::size_type pos,
    typename S::size_type n,
    const typename S::value_type * ptr
);

icompare inline

template < class S > int icompare(
    const S & str,
    typename S::size_type pos,
    const typename S::value_type * ptr
);

icompare inline

template < class S > int icompare(
    const S & str,
    const typename S::value_type * ptr
);

operator inline

inline bool operator == (
    const char & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with char

operator inline

inline bool operator == (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::Int8

operator inline

inline bool operator == (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::UInt8

operator inline

inline bool operator == (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::Int16

operator inline

inline bool operator == (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::UInt16

operator inline

inline bool operator == (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::Int32

operator inline

inline bool operator == (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::UInt32

operator inline

inline bool operator == (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::Int64

operator inline

inline bool operator == (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with Poco::UInt64

operator inline

inline bool operator == (
    const float & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with float

operator inline

inline bool operator == (
    const double & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with double

operator inline

inline bool operator == (
    const bool & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with bool

operator inline

inline bool operator == (
    const std::string & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with std::string

operator inline

inline bool operator == (
    const char * other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with const char*

operator inline

inline bool operator == (
    const long & other,
    const DynamicAny & da
);

Equality operator for comparing DynamicAny with long

operator != inline

inline bool operator != (
    const char & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with char

operator != inline

inline bool operator != (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::Int8

operator != inline

inline bool operator != (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::UInt8

operator != inline

inline bool operator != (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::Int16

operator != inline

inline bool operator != (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::UInt16

operator != inline

inline bool operator != (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::Int32

operator != inline

inline bool operator != (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::UInt32

operator != inline

inline bool operator != (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::Int64

operator != inline

inline bool operator != (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with Poco::UInt64

operator != inline

inline bool operator != (
    const float & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with float

operator != inline

inline bool operator != (
    const double & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with double

operator != inline

inline bool operator != (
    const bool & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with bool

operator != inline

inline bool operator != (
    const std::string & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with std::string

operator != inline

inline bool operator != (
    const char * other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with const char*

operator != inline

inline bool operator != (
    const long & other,
    const DynamicAny & da
);

Inequality operator for comparing DynamicAny with long

operator * inline

inline char operator * (
    const char & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with char

operator * inline

inline Poco::Int8 operator * (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::Int8

operator * inline

inline Poco::UInt8 operator * (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::UInt8

operator * inline

inline Poco::Int16 operator * (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::Int16

operator * inline

inline Poco::UInt16 operator * (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::UInt16

operator * inline

inline Poco::Int32 operator * (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::Int32

operator * inline

inline Poco::UInt32 operator * (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::UInt32

operator * inline

inline Poco::Int64 operator * (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::Int64

operator * inline

inline Poco::UInt64 operator * (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with Poco::UInt64

operator * inline

inline float operator * (
    const float & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with float

operator * inline

inline double operator * (
    const double & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with double

operator * inline

inline long operator * (
    const long & other,
    const DynamicAny & da
);

Multiplication operator for multiplying DynamicAny with long

operator *= inline

inline char operator *= (
    char & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with char

operator *= inline

inline Poco::Int8 operator *= (
    Poco::Int8 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::Int8

operator *= inline

inline Poco::UInt8 operator *= (
    Poco::UInt8 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::UInt8

operator *= inline

inline Poco::Int16 operator *= (
    Poco::Int16 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::Int16

operator *= inline

inline Poco::UInt16 operator *= (
    Poco::UInt16 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::UInt16

operator *= inline

inline Poco::Int32 operator *= (
    Poco::Int32 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::Int32

operator *= inline

inline Poco::UInt32 operator *= (
    Poco::UInt32 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::UInt32

operator *= inline

inline Poco::Int64 operator *= (
    Poco::Int64 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::Int64

operator *= inline

inline Poco::UInt64 operator *= (
    Poco::UInt64 & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with Poco::UInt64

operator *= inline

inline float operator *= (
    float & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with float

operator *= inline

inline double operator *= (
    double & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with double

operator *= inline

inline long operator *= (
    long & other,
    const DynamicAny & da
);

Multiplication assignment operator for multiplying DynamicAny with long

operator + inline

inline const DynamicAny operator + (
    const char * other,
    const DynamicAny & da
);

inlines

DynamicAny members

DynamicAny non-member functions

Addition operator for adding DynamicAny to const char*

operator + inline

inline char operator + (
    const char & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to char

operator + inline

inline Poco::Int8 operator + (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::Int8

operator + inline

inline Poco::UInt8 operator + (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::UInt8

operator + inline

inline Poco::Int16 operator + (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::Int16

operator + inline

inline Poco::UInt16 operator + (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::UInt16

operator + inline

inline Poco::Int32 operator + (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::Int32

operator + inline

inline Poco::UInt32 operator + (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::UInt32

operator + inline

inline Poco::Int64 operator + (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::Int64

operator + inline

inline Poco::UInt64 operator + (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to Poco::UInt64

operator + inline

inline float operator + (
    const float & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to float

operator + inline

inline double operator + (
    const double & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to double

operator + inline

inline long operator + (
    const long & other,
    const DynamicAny & da
);

Addition operator for adding DynamicAny to long

operator += inline

inline char operator += (
    char & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to char

operator += inline

inline Poco::Int8 operator += (
    Poco::Int8 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::Int8

operator += inline

inline Poco::UInt8 operator += (
    Poco::UInt8 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::UInt8

operator += inline

inline Poco::Int16 operator += (
    Poco::Int16 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::Int16

operator += inline

inline Poco::UInt16 operator += (
    Poco::UInt16 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::UInt16

operator += inline

inline Poco::Int32 operator += (
    Poco::Int32 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::Int32

operator += inline

inline Poco::UInt32 operator += (
    Poco::UInt32 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::UInt32

operator += inline

inline Poco::Int64 operator += (
    Poco::Int64 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::Int64

operator += inline

inline Poco::UInt64 operator += (
    Poco::UInt64 & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to Poco::UInt64

operator += inline

inline float operator += (
    float & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to float

operator += inline

inline double operator += (
    double & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to double

operator += inline

inline long operator += (
    long & other,
    const DynamicAny & da
);

Addition assignment operator for adding DynamicAny to long

operator - inline

inline char operator - (
    const char & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from char

operator - inline

inline Poco::Int8 operator - (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::Int8

operator - inline

inline Poco::UInt8 operator - (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::UInt8

operator - inline

inline Poco::Int16 operator - (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::Int16

operator - inline

inline Poco::UInt16 operator - (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::UInt16

operator - inline

inline Poco::Int32 operator - (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::Int32

operator - inline

inline Poco::UInt32 operator - (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::UInt32

operator - inline

inline Poco::Int64 operator - (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::Int64

operator - inline

inline Poco::UInt64 operator - (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from Poco::UInt64

operator - inline

inline float operator - (
    const float & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from float

operator - inline

inline double operator - (
    const double & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from double

operator - inline

inline long operator - (
    const long & other,
    const DynamicAny & da
);

Subtraction operator for subtracting DynamicAny from long

operator -= inline

inline char operator -= (
    char & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from char

operator -= inline

inline Poco::Int8 operator -= (
    Poco::Int8 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::Int8

operator -= inline

inline Poco::UInt8 operator -= (
    Poco::UInt8 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::UInt8

operator -= inline

inline Poco::Int16 operator -= (
    Poco::Int16 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::Int16

operator -= inline

inline Poco::UInt16 operator -= (
    Poco::UInt16 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::UInt16

operator -= inline

inline Poco::Int32 operator -= (
    Poco::Int32 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::Int32

operator -= inline

inline Poco::UInt32 operator -= (
    Poco::UInt32 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::UInt32

operator -= inline

inline Poco::Int64 operator -= (
    Poco::Int64 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::Int64

operator -= inline

inline Poco::UInt64 operator -= (
    Poco::UInt64 & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from Poco::UInt64

operator -= inline

inline float operator -= (
    float & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from float

operator -= inline

inline double operator -= (
    double & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from double

operator -= inline

inline long operator -= (
    long & other,
    const DynamicAny & da
);

Subtraction assignment operator for subtracting DynamicAny from long

operator / inline

inline char operator / (
    const char & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with char

operator / inline

inline Poco::Int8 operator / (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::Int8

operator / inline

inline Poco::UInt8 operator / (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::UInt8

operator / inline

inline Poco::Int16 operator / (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::Int16

operator / inline

inline Poco::UInt16 operator / (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::UInt16

operator / inline

inline Poco::Int32 operator / (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::Int32

operator / inline

inline Poco::UInt32 operator / (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::UInt32

operator / inline

inline Poco::Int64 operator / (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::Int64

operator / inline

inline Poco::UInt64 operator / (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with Poco::UInt64

operator / inline

inline float operator / (
    const float & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with float

operator / inline

inline double operator / (
    const double & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with double

operator / inline

inline long operator / (
    const long & other,
    const DynamicAny & da
);

Division operator for dividing DynamicAny with long

operator /= inline

inline char operator /= (
    char & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with char

operator /= inline

inline Poco::Int8 operator /= (
    Poco::Int8 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::Int8

operator /= inline

inline Poco::UInt8 operator /= (
    Poco::UInt8 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::UInt8

operator /= inline

inline Poco::Int16 operator /= (
    Poco::Int16 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::Int16

operator /= inline

inline Poco::UInt16 operator /= (
    Poco::UInt16 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::UInt16

operator /= inline

inline Poco::Int32 operator /= (
    Poco::Int32 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::Int32

operator /= inline

inline Poco::UInt32 operator /= (
    Poco::UInt32 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::UInt32

operator /= inline

inline Poco::Int64 operator /= (
    Poco::Int64 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::Int64

operator /= inline

inline Poco::UInt64 operator /= (
    Poco::UInt64 & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with Poco::UInt64

operator /= inline

inline float operator /= (
    float & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with float

operator /= inline

inline double operator /= (
    double & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with double

operator /= inline

inline long operator /= (
    long & other,
    const DynamicAny & da
);

Division assignment operator for dividing DynamicAny with long

operator < inline

inline bool operator < (
    const char & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with char

operator < inline

inline bool operator < (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::Int8

operator < inline

inline bool operator < (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::UInt8

operator < inline

inline bool operator < (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::Int16

operator < inline

inline bool operator < (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::UInt16

operator < inline

inline bool operator < (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::Int32

operator < inline

inline bool operator < (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::UInt32

operator < inline

inline bool operator < (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::Int64

operator < inline

inline bool operator < (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with Poco::UInt64

operator < inline

inline bool operator < (
    const float & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with float

operator < inline

inline bool operator < (
    const double & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with double

operator < inline

inline bool operator < (
    const long & other,
    const DynamicAny & da
);

Less than operator for comparing DynamicAny with long

operator <= inline

inline bool operator <= (
    const char & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with char

operator <= inline

inline bool operator <= (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::Int8

operator <= inline

inline bool operator <= (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::UInt8

operator <= inline

inline bool operator <= (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::Int16

operator <= inline

inline bool operator <= (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::UInt16

operator <= inline

inline bool operator <= (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::Int32

operator <= inline

inline bool operator <= (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::UInt32

operator <= inline

inline bool operator <= (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::Int64

operator <= inline

inline bool operator <= (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with Poco::UInt64

operator <= inline

inline bool operator <= (
    const float & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with float

operator <= inline

inline bool operator <= (
    const double & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with double

operator <= inline

inline bool operator <= (
    const long & other,
    const DynamicAny & da
);

Less than or equal operator for comparing DynamicAny with long

operator > inline

inline bool operator > (
    const char & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with char

operator > inline

inline bool operator > (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::Int8

operator > inline

inline bool operator > (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::UInt8

operator > inline

inline bool operator > (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::Int16

operator > inline

inline bool operator > (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::UInt16

operator > inline

inline bool operator > (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::Int32

operator > inline

inline bool operator > (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::UInt32

operator > inline

inline bool operator > (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::Int64

operator > inline

inline bool operator > (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with Poco::UInt64

operator > inline

inline bool operator > (
    const float & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with float

operator > inline

inline bool operator > (
    const double & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with double

operator > inline

inline bool operator > (
    const long & other,
    const DynamicAny & da
);

Greater than operator for comparing DynamicAny with long

operator >= inline

inline bool operator >= (
    const char & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with char

operator >= inline

inline bool operator >= (
    const Poco::Int8 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::Int8

operator >= inline

inline bool operator >= (
    const Poco::UInt8 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::UInt8

operator >= inline

inline bool operator >= (
    const Poco::Int16 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::Int16

operator >= inline

inline bool operator >= (
    const Poco::UInt16 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::UInt16

operator >= inline

inline bool operator >= (
    const Poco::Int32 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::Int32

operator >= inline

inline bool operator >= (
    const Poco::UInt32 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::UInt32

operator >= inline

inline bool operator >= (
    const Poco::Int64 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::Int64

operator >= inline

inline bool operator >= (
    const Poco::UInt64 & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with Poco::UInt64

operator >= inline

inline bool operator >= (
    const float & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with float

operator >= inline

inline bool operator >= (
    const double & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with double

operator >= inline

inline bool operator >= (
    const long & other,
    const DynamicAny & da
);

Greater than or equal operator for comparing DynamicAny with long

priorityDelegate static inline

template < class TObj, class TArgs > static PriorityDelegate < TObj, TArgs, true > priorityDelegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(const void *, TArgs &) param165,
    int prio
);

priorityDelegate static inline

template < class TObj, class TArgs > static PriorityDelegate < TObj, TArgs, false > priorityDelegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(TArgs &) param166,
    int prio
);

priorityDelegate static inline

template < class TObj, class TArgs > static PriorityExpire < TArgs > priorityDelegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(const void *, TArgs &) param167,
    int prio,
    Timestamp::TimeDiff expireMilliSec
);

priorityDelegate static inline

template < class TObj, class TArgs > static PriorityExpire < TArgs > priorityDelegate(
    TObj * pObj,
    void (TObj::* NotifyMethod)(TArgs &) param168,
    int prio,
    Timestamp::TimeDiff expireMilliSec
);

priorityDelegate static inline

template < class TArgs > static PriorityExpire < TArgs > priorityDelegate(
    void (* NotifyMethod)(const void *, TArgs &) param169,
    int prio,
    Timestamp::TimeDiff expireMilliSec
);

priorityDelegate static inline

template < class TArgs > static PriorityExpire < TArgs > priorityDelegate(
    void (* NotifyMethod)(void *, TArgs &) param170,
    int prio,
    Timestamp::TimeDiff expireMilliSec
);

priorityDelegate static inline

template < class TArgs > static PriorityExpire < TArgs > priorityDelegate(
    void (* NotifyMethod)(TArgs &) param171,
    int prio,
    Timestamp::TimeDiff expireMilliSec
);

priorityDelegate static inline

template < class TArgs > static FunctionPriorityDelegate < TArgs, true, true > priorityDelegate(
    void (* NotifyMethod)(const void *, TArgs &) param172,
    int prio
);

priorityDelegate static inline

template < class TArgs > static FunctionPriorityDelegate < TArgs, true, false > priorityDelegate(
    void (* NotifyMethod)(void *, TArgs &) param173,
    int prio
);

priorityDelegate static inline

template < class TArgs > static FunctionPriorityDelegate < TArgs, false > priorityDelegate(
    void (* NotifyMethod)(TArgs &) param174,
    int prio
);

replace inline

template < class S > S replace(
    const S & str,
    const S & from,
    const S & to,
    typename S::size_type start = 0
);

Replace all occurences of from (which must not be the empty string) in str with to, starting at position start.

replace inline

template < class S > S replace(
    const S & str,
    const typename S::value_type * from,
    const typename S::value_type * to,
    typename S::size_type start = 0
);

replaceInPlace inline

template < class S > S & replaceInPlace(
    S & str,
    const S & from,
    const S & to,
    typename S::size_type start = 0
);

replaceInPlace inline

template < class S > S & replaceInPlace(
    S & str,
    const typename S::value_type * from,
    const typename S::value_type * to,
    typename S::size_type start = 0
);

swap inline

template < class C > inline void swap(
    AutoPtr < C > & p1,
    AutoPtr < C > & p2
);

swap inline

inline void swap(
    DateTime & d1,
    DateTime & d2
);

swap inline

inline void swap(
    File & f1,
    File & f2
);

swap inline

inline void swap(
    LocalDateTime & d1,
    LocalDateTime & d2
);

swap inline

inline void swap(
    Message & m1,
    Message & m2
);

swap inline

inline void swap(
    Path & p1,
    Path & p2
);

swap inline

template < class C, class RC, class RP > inline void swap(
    SharedPtr < C,
    RC,
    RP > & p1,
    SharedPtr < C,
    RC,
    RP > & p2
);

swap inline

inline void swap(
    TextIterator & it1,
    TextIterator & it2
);

swap inline

inline void swap(
    Timespan & s1,
    Timespan & s2
);

swap inline

inline void swap(
    Timestamp & s1,
    Timestamp & s2
);

swap inline

inline void swap(
    URI & u1,
    URI & u2
);

swap inline

inline void swap(
    UUID & u1,
    UUID & u2
);

toLower inline

template < class S > S toLower(
    const S & str
);

Returns a copy of str containing all lower-case characters.

toLowerInPlace inline

template < class S > S & toLowerInPlace(
    S & str
);

Replaces all characters in str with their lower-case counterparts.

toUpper inline

template < class S > S toUpper(
    const S & str
);

Returns a copy of str containing all upper-case characters.

toUpperInPlace inline

template < class S > S & toUpperInPlace(
    S & str
);

Replaces all characters in str with their upper-case counterparts.

translate inline

template < class S > S translate(
    const S & str,
    const S & from,
    const S & to
);

Returns a copy of str with all characters in from replaced by the corresponding (by position) characters in to. If there is no corresponding character in to, the character is removed from the copy.

translate inline

template < class S > S translate(
    const S & str,
    const typename S::value_type * from,
    const typename S::value_type * to
);

translateInPlace inline

template < class S > S & translateInPlace(
    S & str,
    const S & from,
    const S & to
);

Replaces in str all occurences of characters in from with the corresponding (by position) characters in to. If there is no corresponding character, the character is removed.

translateInPlace inline

template < class S > S translateInPlace(
    S & str,
    const typename S::value_type * from,
    const typename S::value_type * to
);

trim inline

template < class S > S trim(
    const S & str
);

Returns a copy of str with all leading and trailing whitespace removed.

trimInPlace inline

template < class S > S & trimInPlace(
    S & str
);

Removes all leading and trailing whitespace in str.

trimLeft inline

template < class S > S trimLeft(
    const S & str
);

Returns a copy of str with all leading whitespace removed.

trimLeftInPlace inline

template < class S > S & trimLeftInPlace(
    S & str
);

Removes all leading whitespace in str.

trimRight inline

template < class S > S trimRight(
    const S & str
);

Returns a copy of str with all trailing whitespace removed.

trimRightInPlace inline

template < class S > S & trimRightInPlace(
    S & str
);

Removes all trailing whitespace in str.