►Cstd:: conjunction | |
Crtctk::componentFramework::IsSpanConvertible< T > | Type trait to check if a type can be converted to a Span using AsSpan/ToSpan |
►Crtctk::componentFramework::AbstractEvent | Abstract Event Type that is used as a base for all events |
Crtctk::componentFramework::AlertStatusEvent | Event published when alert status is changed |
►Crtctk::componentFramework::ComputationEvent | Abstract Event Type that is used as a base for computation events |
Crtctk::componentFramework::ComputationFinishedEvent | Event Type used to signal that a computation has finished |
Crtctk::componentFramework::ComputationStartedEvent | Event Type used to signal that a computation has started |
►Crtctk::componentFramework::ConfigurationEvent | Abstract Event Type that is used as a base for configuration events |
Crtctk::componentFramework::ConfigurationRetrievedEvent | Event Type used to signal that a configuration data item was retrieved from RTR |
Crtctk::componentFramework::ConfigurationUpdatedEvent | Event Type used to signal that a configuration data item was updated in RTR |
Crtctk::componentFramework::HrtcConfigurationAppliedEvent | Event Type used to signal that a configuration data item was applied in HRTC |
Crtctk::componentFramework::HrtcConfigurationScheduledEvent | Event Type used to signal that a configuration data item was scheduled to be applied in HRTC |
►Crtctk::componentFramework::CoordinationEvent | Abstract Event Type that is used as a base for coordination events |
►Crtctk::componentFramework::StateChangedEvent | Event Type used to signal that some entity changed its state |
Crtctk::componentFramework::HrtcStateChangedEvent | Event Type used to signal that some entity in HRTC changed its state |
►Cscxml4cpp::Activity | |
Crtctk::componentFramework::ThreadActivity | Class that handles state machine activities |
Crtctk::telSub::AgnosticDataSamples | Container of DDS samples and associated sample information |
Crtctk::componentFramework::AlertStatusEvent::Alert | Represents an active alert originating from a component instance |
Crtctk::rtcSupervisor::AlertAggregator | Class for system status estimation |
Crtctk::componentFramework::AlertInfo | |
►Crtctk::componentFramework::AlertObserverIf | |
Crtctk::componentFramework::AlertEventPublisher | Alert observer that publishes alerts to Event Channel |
Crtctk::componentFramework::AlertLogger | Alert observer that publishes alerts to Log Files |
Crtctk::componentFramework::AlertOldbPublisher | Alert observer that publishes alerts to Online Database |
►Crtctk::componentFramework::AlertServiceIf | Alert Service interface |
Crtctk::componentFramework::AlertService | |
Crtctk::componentFramework::AlertSource | Models a single alert source that can be set or cleared |
Crtctk::componentFramework::AlertStatus | |
Crtctk::mudpiPub::AppCfg | Configuration of entire MUDPI Publisher application |
Crtctk::componentFramework::Args | Class used to parse default command line arguments |
Crtctk::componentFramework::AsSpan< T > | Gets the span type for converting type T to a span |
Crtctk::componentFramework::AsSpan< const std::array< T, Size > > | |
Crtctk::componentFramework::AsSpan< MatrixBuffer< T, Allocator > > | |
Crtctk::componentFramework::AsSpan< std::array< T, Size > > | |
Crtctk::componentFramework::AsSpan< std::vector< T, Allocator > > | |
►Crtctkif::AsyncAlertCmds | |
Crtctk::componentFramework::AlertCmdsImpl | Class that handles reception of command ClearAlerts using MAL |
►Crtctkexif::AsyncCustomCmds | |
Crtctk::exampleCustom::CustomCmdsImpl | |
►Crtctkif::AsyncDeploymentCmds | |
Crtctk::deploymentDaemon::DeploymentCmdsImpl | Class that handles reception of DeploymentCmds commands |
►Crtctkif::AsyncFuncCmds | |
Crtctk::componentFramework::FuncCmdsImpl | Class that handles reception of commands Run, Idle and Recover using MAL |
►Cintrospectionif::AsyncIntrospection | |
Crtctk::componentFramework::IntrospectionImpl | Class that handles reception of introspection commands |
►Crtctkif::AsyncLoopCmds | |
Crtctk::componentFramework::LoopCmdsImpl | Class that handles reception of commands Open and Close using MAL |
►Crtctkif::AsyncMeasCmds | |
Crtctk::componentFramework::MeasCmdsImpl | Class that handles reception of command Measure using MAL |
►Cmetadaqif::AsyncMetaDaq | |
Crtctk::metadataCollector::AcquisitorCmdsImpl | Class that handles reception of metadaqif commands using MAL |
►Crtctkif::AsyncModeCmds | |
Crtctk::rtcSupervisor::ModeCmdsImpl | Class that handles reception of mode-related commands using MAL |
►Crtctkif::AsyncOptCmds | |
Crtctk::componentFramework::OptCmdsImpl | Class that handles reception of command Optimise using MAL |
►Crtctkif::AsyncRecoverCmds | |
Crtctk::componentFramework::RecoverCmdsImpl | Class that handles reception of command Recover using MAL |
►Cstdif::AsyncStdCmds | |
Crtctk::componentFramework::StdCmdsImpl | Class that handles reception of stdif commands |
►Crtctkif::AsyncSuspCmds | |
Crtctk::componentFramework::SuspCmdsImpl | Class that handles reception of commands Suspend and Resume using MAL |
►Crtctkif::AsyncUpdateCmds | |
Crtctk::componentFramework::UpdateCmdsImpl | Class that handles reception of command Update using MAL |
►Crtctkif::AsyncWriteBackCmds | |
Crtctk::rtcSupervisor::WriteBackCmdsImpl | Class that handles reception of writeback-related commands using MAL |
►Crtctk::componentFramework::RepositoryIf::BatchRequest | An object representing one or more asynchronous I/O requests to a repository |
Crtctk::componentFramework::RepositorySubscriberIf::BatchRequest | |
Crtctk::componentFramework::RepositoryIf::BatchResponse | |
►Crtctk::componentFramework::StdComponent::BizLogicIf | |
►Crtctk::componentFramework::RtcComponent::BizLogicIf | |
CBusinessLogic | |
►Crtctk::deploymentDaemon::DeploymentDaemonLifeCycle::BizLogicIf | |
Crtctk::deploymentDaemon::DeploymentDaemonBusinessLogic | Deployment Daemon business logic |
►CSuper::BizLogicIf | |
Crtctk::componentFramework::Loopaware< Super >::BizLogicIf | |
Crtctk::componentFramework::Measurable< Super >::BizLogicIf | Business logic interface for Measurable mixin |
Crtctk::componentFramework::Optimisable< Super >::BizLogicIf | Business logic interface for Optimisable mixin |
►Crtctk::componentFramework::Runnable< Super >::BizLogicIf | |
Crtctk::ddtServer::BusinessLogic | Defines and implements the business logic of the DDT Server, an RTC Component that subscribes to a shared memory queue, and publishes samples through DDT |
Crtctk::exampleComponent::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::mudpiPub::BusinessLogic | |
Crtctk::telRepub::TelRepubBusinessLogic | Telemetry Republisher business logic |
Crtctk::telSub::BusinessLogic | Implements the Telemetry Subscriber business logic |
Crtctk::telemetryRecorder::BusinessLogic | Business Logic implementation for a Telemetry Recorder instance |
Crtctk::componentFramework::Suspendable< Super >::BizLogicIf | |
►Crtctk::exampleCustom::CustomLifeCycle< Super >::BizLogicIf | |
Crtctk::exampleCustom::BusinessLogic | |
►Crtctk::metadataCollector::Acquisitor< Super >::BizLogicIf | |
Crtctk::metadataCollector::BusinessLogic | Business logic class for the Metadata Collector |
►Crtctk::rtcSupervisor::Supervisory< Super >::BizLogicIf | Business logic interface for Supervisory mixin |
Crtctk::rtcSupervisor::RtcSupervisor | |
Crtctk::telSub::ShmPublisherIf::BlenderError | |
Crtctk::componentFramework::BufferManager | BufferManager is a class that will allocate a big buffer and spit it up in several cache-aligned sub-buffers |
Crtctk::componentFramework::BufferMonitor< ClockType > | Monitors min, mean and max occupation of a buffer and publishes them to OLDB |
Crtctk::componentFramework::BufferManager::BufferReference | |
►Crtctk::telRepub::CfgMudpiProc | Structure to hold MudpiProcessor's configuration |
Crtctk::telRepub::CfgPubThreadMudpi | Structure to hold PubThreadMudpi's configuration |
►Crtctk::telRepub::CfgPubThread | Structure to hold PubThread's configuration |
Crtctk::telRepub::CfgPubThreadMudpi | Structure to hold PubThreadMudpi's configuration |
Crtctk::telRepub::MudpiProcessorError::ChecksumError | MUDPI Checksum error |
►Celt::error::CiiBaseException | |
►Crtctk::componentFramework::RtctkException | Base class for all Rtctk exceptions |
Crtctk::componentFramework::AdapterCreationException | Thrown from service factory methods to indicate the adapter construction failed |
Crtctk::componentFramework::AlertConflictException | Exception indicating that an alert conflicts with already known alert |
Crtctk::componentFramework::AlertUnknownException | Exception indicating that an alert does not exist |
►Crtctk::componentFramework::BufferTooSmall | The BufferTooSmall is thrown when an API call fails because the provided buffer is not big enough to hold the data |
Crtctk::componentFramework::RepositoryIf::BufferTooSmall | |
Crtctk::componentFramework::DataPointPath::InvalidPathException | Exception class used when an invalid character is used in a DataPointPath |
Crtctk::componentFramework::DdtError | This Exception is raised when the DDT Publisher returns an error that cannot be handled by the DDT Sink |
Crtctk::componentFramework::DdtSinkNotFound | This Exception is raised when an invalid ddt sink is requested |
Crtctk::componentFramework::FitsDataRecorderFitsError | |
Crtctk::componentFramework::InitialisationException | Thrown in cases where an initialisation routine has failed |
Crtctk::componentFramework::InvalidArgumentException | Thrown if an argument passed to a method was invalid |
Crtctk::componentFramework::InvalidSetting | This Exception is raised when a invalid setting was used in the runtime repo |
Crtctk::componentFramework::InvalidStateChange | This Exception is raised when the state change requested is invalid |
Crtctk::componentFramework::IpcqError | This Exception is raised when the ipc queue returns an error that cannot be handled by the Telemetry Source Thread |
Crtctk::componentFramework::MetricConflictException | Exception indicating that a metric such as counter or thread conflicts with already known metrics |
Crtctk::componentFramework::NoBufferAvailableException | |
Crtctk::componentFramework::NotImplementedException | The NotImplementedException is thrown whenever an attempt is made to use a feature or function that has not been implemented |
Crtctk::componentFramework::PersistentRepoAdapter::InvalidDocumentException | Exception indicating that validation checks of a CII configuration document failed |
Crtctk::componentFramework::PersistentRepoAdapter::PathMissingException | Exception indicating a datapoint path does not exist |
Crtctk::componentFramework::PersistentRepoAdapter::ServiceFailureException | Exception indicating a general CII configuration service error |
Crtctk::componentFramework::PopulateConfig::InvalidConfigException | The InvalidConfigException is thrown when configuration errors are found in the Persistent Configuration Repository |
Crtctk::componentFramework::PopulateConfig::InvalidDataPointException | The InvalidDataPointException is thrown when datapoints in the Persistent Configuration Repository are discovered to have invalid values |
Crtctk::componentFramework::PopulateConfig::RepositoryServiceException | The RepositoryServiceException is thrown when unexpected problems arise accessing the underlying repository service |
Crtctk::componentFramework::PythonInterpreter::SetupFailure | This exception is raised when the Python interpreter cannot be initialised properly |
Crtctk::componentFramework::RepositoryIf::AccessOutOfBounds | |
Crtctk::componentFramework::RepositoryIf::DataPointAlreadyExists | |
Crtctk::componentFramework::RepositoryIf::DataPointDoesNotExist | |
Crtctk::componentFramework::RepositoryIf::IncompatibleType | |
Crtctk::componentFramework::RepositoryIf::MetaData::KeyAlreadyExists | Exception indicating that the metadata already contains the given key |
Crtctk::componentFramework::RepositoryIf::MetaData::KeyDoesNotExist | Exception indicating that the given key does not exist in the metadata |
Crtctk::componentFramework::RepositoryIf::MetaData::TypeMismatch | Exception indicating that a value with the wrong type was being assigned to a reserved key |
Crtctk::componentFramework::RepositoryIf::MultipleRequestsFailed | |
Crtctk::componentFramework::RepositoryIf::OperationNotAllowed | |
Crtctk::componentFramework::RepositoryIf::ServiceFailure | |
Crtctk::componentFramework::RepositorySubscriberIf::SequenceIdMissmatch | |
Crtctk::componentFramework::RepositorySubscriberIf::SubscriptionError | |
Crtctk::componentFramework::ServiceRegistryIf::ConsulUnavailable | |
Crtctk::componentFramework::ServiceRegistryIf::InvalidComponent | |
Crtctk::componentFramework::ServiceRegistryIf::InvalidService | |
►Crtctk::componentFramework::UnsupportedTypeException | The UnsupportedTypeException is thrown whenever an attempt is made to use an unsupported type in the RTC Toolkit API |
Crtctk::componentFramework::RepositoryIf::MetaData::UnsupportedType | Exception indicating that an unsupported type was used for the metadata value |
Crtctk::componentFramework::RepositoryIf::UnsupportedType | |
Crtctk::componentFramework::UnsupportedUriException | The UnsupportedUriException is thrown whenever an attempt is made to use an unsupported URI in the RTC Toolkit API |
Crtctk::rtcSupervisor::CommandFailedException | Dedicated exception type to indicate errors |
Celt::configng::CiiConfigValueConverter< RtcTypeInfo, CiiConfigInstanceNode > | |
Crtctk::componentFramework::DataRecorder< T >::ColumnMetaData | |
CCombinedFrames | Data about the combined packets of a single sample |
Crtctk::componentFramework::CommandReplier | Class that handles reception of commands using MAL |
►Crtctk::componentFramework::CommandRequestor | Extendable class that allows to send commands to components using MAL |
CMyCommandRequestor | |
Crtctk::metadataCollector::CommandRequestor | |
►Crtctk::componentFramework::ComponentMetricsIf | Component metrics interface |
Crtctk::componentFramework::ComponentMetrics | Implementation of ComponentMetricsIf |
Crtctk::componentFramework::FakeComponentMetrics | |
Crtctk::componentFramework::MockComponentMetrics | |
Crtctk::componentFramework::MockComponentMetrics | |
Crtctk::dataTask::ComputationBase< TopicTypeX, ReaderType > | Base class for Data Task computations |
►Crtctk::dataTask::ComputationBase< TopicType > | |
Crtctk::exampleDataTask::Computation | |
Crtctk::exampleDataTask::Computation | |
Crtctk::exampleDataTask::Computation | |
Crtctk::componentFramework::RepositoryIf::MetaData::ConstIterator | Constant version of the bidirectional forward iterator returned by the cbegin/cend methods |
Crtctk::componentFramework::RepositoryIf::MetaData::ConstReverseIterator | Constant version of the bidirectional reverse iterator returned by the crbegin/crend methods |
Crtctk::componentFramework::RepositoryIf::MetaData::ConstValueProxy | A read-only interface class to an underlying metadata value |
Crtctk::telSub::CorrelationFailedError | |
►Crtctk::telSub::CorrelatorIf | Interface for correlator implemementations that takes new data samples from DDS and performs correlation on them |
Crtctk::telSub::Correlator | Implements a correlator |
Crtctk::telSub::MockCorrelatorIf | |
Crtctk::telSub::CorrelatorParams | Placeholder for correlator parameters |
Crtctk::componentFramework::CounterMetricInfo | Defines auxiliary information associated with each counter registered with ComponentMetricsIf |
Crtctk::componentFramework::detail::CreateDeleteSubscribeRequest | |
Crtctk::componentFramework::RuntimeRepoAdapter::CreateDeleteSubscription | |
Crtctk::componentFramework::test::FakeRepositorySubscriber::CreateDeleteSubscription | |
Crtctk::componentFramework::detail::CreateRequest< T > | |
Crtctk::componentFramework::detail::CreateSymlinkRequest | |
►Cmetadaqif::DaqException | |
Crtctk::metadataCollector::DaqRequestRejected | Thrown if command is not allowed in current state or guard |
►Cmetadaqif::DaqReply | |
Crtctk::metadataCollector::DaqReply | |
►Cmetadaqif::DaqStatus | |
Crtctk::metadataCollector::DaqStatus | |
►Cmetadaqif::DaqStopReply | |
Crtctk::metadataCollector::DaqStopReply | |
Crtctk::componentFramework::test::FakeRepository::Data | |
CDataPoint | |
Crtctk::componentFramework::DataPointPath | This class provides a wrapper for a data point path |
►Crtctk::componentFramework::DataReaderListener | |
CGenSubReaderListener | DDS Listener |
Crtctk::componentFramework::DdsReaderListener | Listener class for different DDS events |
Crtctk::telSub::DdsReaderListener | Listener class for different DDS events |
Crtctk::componentFramework::DataRecorder< T > | This is an abstract class that can be used to implement an OutputStage for a Recording Unit |
►Crtctk::componentFramework::DataRecorder< T... > | |
Crtctk::componentFramework::CsvDataRecorder< taiclock::TaiClock::time_point::rep, std::string > | |
CFakeRecorder< T > | |
Crtctk::componentFramework::CsvDataRecorder< T > | Recorder used for writing data to a CSV file |
Crtctk::componentFramework::FitsRecorder< T > | |
Crtctk::telSub::DataSamplesView | A set of correlated agnostic non-owning data samples references |
Crtctk::telSub::DataSampleView | Agnostic data sample non-owning reference type |
►CDataWriterListener | |
Crtctk::componentFramework::DdsWriterListener | Listener class for differetn DDS events |
►Crtctk::componentFramework::Dds | Common functionallty needed to create DDS entities like participant and topic that can be later used (extent) for DDS data publishing and subscribing |
Crtctk::componentFramework::DdsPub | All functionallty needed to create DDS entities for DDS data publishing is concentrated in this class |
Crtctk::componentFramework::DdsSub | All functionality needed to create DDS entities for DDS data subscribing is concentrated in this class |
Crtctk::telSub::DdsParams | Parameter set to be passed to classes deriving from DdsWaitSetIf |
Crtctk::componentFramework::DdsReaderParams | Structure that keeps together topic name and DDS Data Writer listener |
Crtctk::telSub::DdsTopicOptions | Options for a single topic |
Crtctk::telSub::DdsWaitSetError | Error reporting struct, contains the return code and topic where the error occurred |
►Crtctk::telSub::DdsWaitSetIf | Base class abstracting DDS communication code |
Crtctk::telSub::DdsWaitSet | Implements DDS communication using FastDDS |
Crtctk::telSub::FakeDdsSubscriber | Fake DDS subscriber |
Crtctk::telSub::MockDdsWaitSet | |
Crtctk::componentFramework::DdsWriterParams | Structure that keeps together topic name and DDS Data Writer listener |
►Crtctk::ddtServer::DdtForwarder | Base class defining common interface for all DDT forwarders |
Crtctk::ddtServer::IpcqDdtForwarder< FwdInfo, ReaderType > | DDT Forwarder unit that ingests data from from SHM and republishes it on several DDT streams |
Crtctk::ddtServer::DdtPublisherImage1d< SI > | DDT Publisher class used to publish one-dimensional DDT streams |
Crtctk::ddtServer::DdtPublisherImage2d< SI > | DDT Publisher class used to publish two-dimensional DDT streams |
Crtctk::componentFramework::DebugExport | |
Crtctk::componentFramework::detail::DeleteRequest | |
Crtctk::deploymentDaemon::DeploymentDaemonLifeCycle | Life cycle for DeploymentDaemonComponent |
►Crtctkif::DeploymentException | |
Crtctk::deploymentDaemon::DeploymentAlreadyExists | Thrown if the command is not allowed because there is already deployment (= in Deployment State) |
Crtctk::deploymentDaemon::DeploymentDaemonRequestAborted | Thrown if somebody sent a stop or abort command |
Crtctk::deploymentDaemon::DeploymentDaemonRequestFailed | Thrown if the command was accepted but the task to run failed |
Crtctk::deploymentDaemon::DeploymentDaemonRequestRejected | Thrown if the command is not allowed in current state |
Crtctk::deploymentDaemon::NoDeployment | Thrown if the command is not allowed because there is no deployment (=not in Deployment State) |
Crtctk::componentFramework::Deserialiser< T > | Deserialisation helper class for reading, it provides a writable byte span to the RtrClient |
Crtctk::componentFramework::Deserialiser< std::string > | |
Crtctk::componentFramework::DurationMonitor< ClockType > | Monitors min, mean and max duration and publishes them to OLDB |
Crtctk::telRepub::ErrorCode< ErrorStruct > | |
CEventPublisher | |
►Crtctk::componentFramework::EventPublisherIf | Interface class for publishing JSON events |
CMockEventPublisher | |
CMockEventPublisher | |
Crtctk::componentFramework::MalDdsEventPublisher | Implementation of event publisher |
CEventQueue | |
►Crtctk::componentFramework::EventServiceIf | Interface class for providing pub/sub facilities for JSON events |
CMockEventService | |
CMockEventService | |
Crtctk::componentFramework::MalDdsEventService | Implementation of low-level event service using CII MAL DDS as middleware |
►Crtctk::componentFramework::EventSubscriberIf | Interface class for subscribing to JSON events |
CMockEventSubscriber | |
CMockEventSubscriber | |
Crtctk::componentFramework::MalDdsEventSubscriber | Implementation of event subscriber |
►Crtctkif::ExceptionErr | |
Crtctk::componentFramework::RequestAborted | Thrown if somebody sent a stop or abort command |
Crtctk::componentFramework::RequestFailed | Thrown if the command was accepted but the task to run failed |
Crtctk::componentFramework::RequestRejected | Thrown if a command is not allowed in current state or guard |
►Cstdif::ExceptionErr | |
Crtctk::componentFramework::StdIfRequestAborted | Thrown if somebody sent a stop or abort command |
Crtctk::componentFramework::StdIfRequestFailed | Thrown if the command was accepted but the task to run failed |
Crtctk::componentFramework::StdIfRequestRejected | Thrown if the command is not allowed in current state or guard |
Crtctk::componentFramework::detail::ExistsRequest | |
CIpcqDdtForwarderInfo::ExtractedPupilsDdtStreamInfo | |
►Crtctk::componentFramework::FactoryRegistry< BaseIf >::FactoryIf | The base class for all factory objects that are registered in the FactoryRegistry |
Crtctk::componentFramework::RepositoryFactory< BaseIf, Adapter > | A base class for factories that create instances of repository adapters from URIs |
Crtctk::componentFramework::FactoryRegistry< BaseIf > | A simple registry of various factory objects |
Crtctk::componentFramework::test::FakeClock | |
CFakeReaderBase< TopicType, max_reads > | |
CFakeServices | |
►Cstd::false_type | |
Crtctk::componentFramework::HasSampleIdWithCorrectType< T, typename > | |
Crtctk::componentFramework::IsAdapterIdTypeDefined< class, class > | Structure for detecting if a class declared a type called AdapterIdType using SFINAE |
Crtctk::componentFramework::IsComplexType< typename > | Structure for detecting std::vector types using SFINAE |
Crtctk::componentFramework::IsDynamicSpanType< typename > | Structure for detecting gsl::span types of dynamic size using SFINAE |
Crtctk::componentFramework::IsMatrixBufferType< typename > | Structure for detecting MatrixBuffer types using SFINAE |
Crtctk::componentFramework::IsMatrixSpanType< typename > | Structure for detecting MatrixSpan types using SFINAE |
Crtctk::componentFramework::IsSpanType< typename > | Structure for detecting gsl::span types using SFINAE |
Crtctk::componentFramework::IsStaticSpanType< typename > | Structure for detecting gsl::span types of fixed size using SFINAE |
Crtctk::componentFramework::IsStdArrayType< typename > | Structure for detecting std::array types using SFINAE |
Crtctk::componentFramework::IsSupportedUriSchemeDefined< class, class > | Structure for detecting if a class declared a member called SUPPORTED_URI_SCHEME using SFINAE |
Crtctk::componentFramework::IsVectorType< typename > | Structure for detecting std::vector types using SFINAE |
Crtctk::componentFramework::PathMapper::FilePathResult | Result object returned by the PathToFile method |
Crtctk::componentFramework::FitsColumn | |
Crtctk::componentFramework::FitsColumnFormat< T, _ > | Type that stores type information for a FITS TFORM string |
Crtctk::componentFramework::FitsColumnFormat< bool > | |
Crtctk::componentFramework::FitsColumnFormat< double > | |
Crtctk::componentFramework::FitsColumnFormat< float > | |
Crtctk::componentFramework::FitsColumnFormat< int16_t > | |
Crtctk::componentFramework::FitsColumnFormat< int32_t > | |
Crtctk::componentFramework::FitsColumnFormat< int64_t > | |
Crtctk::componentFramework::FitsColumnFormat< int8_t > | |
Crtctk::componentFramework::FitsColumnFormat< std::string > | |
Crtctk::componentFramework::FitsColumnFormat< T, typename std::enable_if< IS_DYNAMIC_SPAN_TYPE< T > >::type > | |
Crtctk::componentFramework::FitsColumnFormat< T, typename std::enable_if< IS_MATRIX_BUFFER_TYPE< T > >::type > | |
Crtctk::componentFramework::FitsColumnFormat< T, typename std::enable_if< IS_STATIC_SPAN_TYPE< T > >::type > | |
Crtctk::componentFramework::FitsColumnFormat< T, typename std::enable_if< IS_STD_ARRAY_TYPE< T > >::type > | |
Crtctk::componentFramework::FitsColumnFormat< T, typename std::enable_if< IS_VECTOR_TYPE< T > >::type > | |
Crtctk::componentFramework::FitsColumnFormat< uint16_t > | |
Crtctk::componentFramework::FitsColumnFormat< uint32_t > | |
Crtctk::componentFramework::FitsColumnFormat< uint64_t > | |
Crtctk::componentFramework::FitsColumnFormat< uint8_t > | |
►CFitsConverterIf | |
CGenericCamera | The GenericCamera implements a Camera that saves the packet data, without combining the data into a FITS binary table |
CLisaCamera | |
CFITSRecorder | This class creates a FITS file containing a single binary table |
►Cformatter | |
Cfmt::formatter< eprosima::fastdds::dds::SampleRejectedStatusKind > | |
Cfmt::formatter< rtctk::rtcSupervisor::RtcCommand > | Formatter for RtcObject |
►Cformatter fmt::formatter | |
Cfmt | Formatter class to allow using DataPointPath with fmt::format |
CFrameIdentifier | Unique identifier for packets of a single frame |
Crtctk::telRepub::MudpiProcessorError::FrameIdOutOfRange | FrameId out of range |
CFrameMetadata | Metadata for a single frame |
Crtctk::componentFramework::FrequencyEstimator< ClockType > | Estimates the frequency in which Tick is called and publishes result to OLDB |
Crtctk::standaloneTools::GenDdsPublisher | Generic DDS Publisher Class provides functionally to create one DDS Topic and one DDS DataWriter, and one thread that first waits for a given number of data readers/subscribers and after publishing sampels in a loop |
►Crtctk::standaloneTools::GenRtrWriterBase | Base class for Generic RTR Writer |
Crtctk::standaloneTools::GenRtrWriter< T > | Generic RTR Writer Class provides functionally to create one RTR's DP DDS, and one thread that writes value to the DP in a loop |
Crtctk::componentFramework::detail::GetChildrenRequest | |
CGpuLib | |
Crtctk::componentFramework::RepositoryIf::MultipleRequestsFailed::Info | |
►Crtctk::componentFramework::StdComponent::InputStage | |
Crtctk::componentFramework::RtcComponent::InputStage | |
Crtctk::deploymentDaemon::DeploymentDaemonLifeCycle::InputStage | |
►CSuper::InputStage | |
Crtctk::componentFramework::Loopaware< Super >::InputStage | |
Crtctk::componentFramework::Measurable< Super >::InputStage | |
Crtctk::componentFramework::Optimisable< Super >::InputStage | |
Crtctk::componentFramework::Runnable< Super >::InputStage | |
Crtctk::componentFramework::Suspendable< Super >::InputStage | |
Crtctk::exampleCustom::CustomLifeCycle< Super >::InputStage | |
Crtctk::metadataCollector::Acquisitor< Super >::InputStage | |
Crtctk::rtcSupervisor::Supervisory< Super >::InputStage | |
CIpcqDdtForwarderInfo | |
CIpcqRecordingInfo | |
Crtctk::componentFramework::is_base_of_template_impl< Base, Derived > | |
Crtctk::componentFramework::RepositoryIf::MetaData::Iterator | Bidirectional forward iterator returned by the begin/end methods |
Crtctk::telSub::OperationalLogicIf::LastError | Describes last errors |
Crtctk::exampleTopic::LgsPixelTopic | |
►Crtctkif::LogInfo | |
Crtctk::deploymentDaemon::LogInfoImpl | Implementation of LogInfo structure for Deployment Daemon defined in ICD |
►Cstdif::LogInfo | |
Crtctk::componentFramework::LogInfo | |
Crtctk::componentFramework::LogInitializer | RAII class to clean-up logging without leaking memory |
Crtctk::metadataCollector::Loopaware< Super > | |
Crtctk::exampleTopic::McaoLoopTopic | |
Crtctk::componentFramework::detail::MeasureContext | Holds context necessary for processing a measure request to completion |
Crtctk::componentFramework::RepositoryIf::MetaData | Class for passing/receiving metadata to/from the repository |
Crtctk::componentFramework::test::MockCallbacks | |
Crtctk::componentFramework::test::MockExtRedisBackend | Mock interface representing the external Redis backend |
►CSuper::ModelBuilder | |
Crtctk::componentFramework::Loopaware< Super >::ModelBuilder | |
Crtctk::componentFramework::Measurable< Super >::ModelBuilder | |
Crtctk::componentFramework::Optimisable< Super >::ModelBuilder | |
Crtctk::componentFramework::Runnable< Super >::ModelBuilder | |
Crtctk::componentFramework::Suspendable< Super >::ModelBuilder | |
Crtctk::exampleCustom::CustomLifeCycle< Super >::ModelBuilder | |
Crtctk::metadataCollector::Acquisitor< Super >::ModelBuilder | |
Crtctk::rtcSupervisor::Supervisory< Super >::ModelBuilder | |
►Crtctk::componentFramework::ModelBuilderBase | Base class of the ModelBuilder |
►Crtctk::componentFramework::StdComponent::ModelBuilder | |
Crtctk::componentFramework::RtcComponent::ModelBuilder | |
Crtctk::deploymentDaemon::DeploymentDaemonLifeCycle::ModelBuilder | |
Crtctk::componentFramework::ModelManipulator | Class that provides methods to manipulate the state machine model |
Crtctk::telRepub::MudpiProcessor | Processing MUDPI data received by UDP receiver: rtctk::telRepub::UdpReceiver |
Crtctk::telRepub::MudpiProcessorError | MUDPI Processor errors |
►Cstd::nested_exception | |
Crtctk::componentFramework::detail::UnspecifiedNested< T > | Unspecified exception used by WrapWithNested |
Crtctk::componentFramework::NestedExceptionPrinter | Adapter object intended to be used in contexts without direct access to the output-stream object |
►Ctesting::NiceMock | |
Crtctk::componentFramework::test::FakeRedisProvider | A fake provider that can also be used for external Redis unit testing |
Crtctk::telSub::OperationalLogicFactoryParams | Set of all parameters needed when constructing the OperationalLogic object |
►Crtctk::telSub::OperationalLogicIf | Interface to the operational logic implementation |
Crtctk::telSub::OperationalLogic | Implements the behaviour for Operational state |
Crtctk::telSub::OperationalParams | Configuration parameters needed for operational logic |
Crtctk::componentFramework::detail::OptimiseContext | Holds context necessary for processing a optimise request to completion |
►Crtctk::componentFramework::StdComponent::OutputStage | |
Crtctk::componentFramework::RtcComponent::OutputStage | |
Crtctk::deploymentDaemon::DeploymentDaemonLifeCycle::OutputStage | |
►CSuper::OutputStage | |
Crtctk::componentFramework::Loopaware< Super >::OutputStage | |
Crtctk::componentFramework::Measurable< Super >::OutputStage | |
Crtctk::componentFramework::Optimisable< Super >::OutputStage | |
Crtctk::componentFramework::Runnable< Super >::OutputStage | |
Crtctk::componentFramework::Suspendable< Super >::OutputStage | |
Crtctk::exampleCustom::CustomLifeCycle< Super >::OutputStage | |
Crtctk::metadataCollector::Acquisitor< Super >::OutputStage | |
Crtctk::rtcSupervisor::Supervisory< Super >::OutputStage | |
CPacketCombiner | This class combines the packets of a sample |
CPacketData | |
CPacketDumper | PacketDumper class to capture packets via libpcap |
Crtctk::telRepub::PacketFrame | |
Crtctk::telRepub::MudpiProcessorError::PacketSizeError | (UDP) Packet Size error |
Crtctk::componentFramework::ComponentMetrics::Parameters | Runtime parameters |
Crtctk::componentFramework::RepositoryIf::ReadRequest::Parameters | A structure to hold the arguments passed with one of the Add methods |
Crtctk::componentFramework::RepositoryIf::WriteRequest::Parameters | A structure to hold the arguments passed with one of the Add methods |
Crtctk::componentFramework::RepositorySubscriberIf::SubscribeRequest::Parameters | A structure to hold the arguments passed to the Add method |
Crtctk::componentFramework::RepositorySubscriberIf::UnsubscribeRequest::Parameters | A structure to hold the arguments passed with one of the Add methods |
Crtctk::componentFramework::detail::PartialReadRequest< T > | |
Crtctk::componentFramework::detail::PartialWriteRequest< T > | |
Crtctk::componentFramework::PathMapper | Used to calculate URIs from datapoint paths |
Crtctk::exampleTopic::PixelBaseTopic< NPIX > | |
Crtctk::exampleTopic::PixelSuperTopic | |
Crtctk::componentFramework::PlantUmlExport | |
Crtctk::componentFramework::PopulateConfig | A utility class used to populate the Runtime Configuration Repository |
►Crtctk::mudpiPub::PubDynamicCfg | Dynamic Configuration of a single MUDPI Publisher object |
Crtctk::mudpiPub::PubCfg | Configuration (Dynamic + Static) of a single MUDPI Publisher object |
Celt::mal::ps::Publisher< TOPIC_TYPE > | |
Crtctk::mudpiPub::Publisher | |
►Crtctk::mudpiPub::PubStaticCfg | Static Configuration of a single MUDPI Publisher object |
Crtctk::mudpiPub::PubCfg | Configuration (Dynamic + Static) of a single MUDPI Publisher object |
►Crtctk::telRepub::PubThread | DDS publisher thread class that supports production and simulation mode |
Crtctk::telRepub::PubThreadMudpi | DDS publisher thread class that supports (re)publishing of MUDPI samples |
Crtctk::telRepub::PubThreadSim | DDS publisher thread class that supports simulation mode |
Crtctk::componentFramework::PythonInterpreter | Helper class for managing the lifecycle of an embedded Python interpreter |
Crtctk::deploymentDaemon::DeploymentDaemonBusinessLogic::PythonObjects | |
CIpcqDdtForwarderInfo::RawPixelFrameDdtStreamInfo | |
CIpcqDdtForwarderInfo::RawPixelFrameDdtStreamInfo1d | |
CIpcqDdtForwarderInfo::RawPupilQuadrantDtStreamInfo | |
Crtctk::componentFramework::detail::ReadMetaDataRequest | |
Crtctk::componentFramework::detail::ReadRequest< T > | |
Crtctk::componentFramework::RepositoryIf::ReadRequest | A request object to pass information about datapoints that should be read from the repository |
Crtctk::componentFramework::RecordingInfo< T > | |
Crtctk::componentFramework::RecordingInfo< AlertStatusEvent > | Trait class that defines how AlertStatusEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ComputationEvent > | Trait class that defines how ComputationEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ComputationFinishedEvent > | Trait class that defines how ComputationFinishedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ComputationStartedEvent > | Trait class that defines how ComputationStartedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ConfigurationEvent > | Trait class that defines how ConfigurationEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ConfigurationRetrievedEvent > | Trait class that defines how ConfigurationRetrievedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< ConfigurationUpdatedEvent > | Trait class that defines how ConfigurationUpdatedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< CoordinationEvent > | Trait class that defines how CoordinationEvent is recorded |
Crtctk::componentFramework::RecordingInfo< EventType > | |
Crtctk::componentFramework::RecordingInfo< HrtcConfigurationAppliedEvent > | Trait class that defines how HrtcConfigurationAppliedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< HrtcConfigurationScheduledEvent > | Trait class that defines how HrtcConfigurationScheduledEvent is recorded |
Crtctk::componentFramework::RecordingInfo< HrtcStateChangedEvent > | Trait class that defines how HrtcStateChangedEvent is recorded |
Crtctk::componentFramework::RecordingInfo< StateChangedEvent > | Trait class that defines how StateChangedEvent is recorded |
►Crtctk::componentFramework::RecordingUnit | Abstract base class for all sources that can be recorded by the MetadataCollector and TelemetryRecorder |
Crtctk::componentFramework::DataPointRecordingUnit< DpType > | Recording Unit that can record datapoints |
Crtctk::componentFramework::DynamicDataPointRecordingUnit | Recording unit that takes datapoints from RuntimeRepo path "/component_id/dynamic/rec_units/unit_id/datapoint_list" in the format "oldb:..." or "rtr:..." and creates internal DataPointRecordingUnits that record the given paths |
Crtctk::componentFramework::IpcqRecordingUnit< RecInfoType > | Recording Unit that can record from shared memory queue |
Crtctk::componentFramework::JsonEventRecordingUnit< OutputStage > | Recording Unit that can record JSON events |
Crtctk::componentFramework::TypedEventRecordingUnit< EventType, OutputStage > | Recording Unit that can record typed events |
Crtctk::componentFramework::RegisterFactory< BaseIf, Factory > | A helper class used to perform registration and deregistration of a factory |
►Crtctk::componentFramework::RepositoryIf | Abstract interface providing basic read and write facilities to a repository |
►Crtctk::componentFramework::PersistentRepoIf | Base interface for all Persistent Configuration Repository adapters |
Crtctk::componentFramework::PersistentRepoAdapter | Implements the Persistent Configuration Repository adapter that uses the CII configuration service as the backend |
Crtctk::componentFramework::test::FakePersistentRepoIf | Implementation of a fake of PersistentRepoIf for testing |
Crtctk::componentFramework::test::MockPersistentRepoIf | A mock of PersistentRepoIf |
►Crtctk::componentFramework::RepositorySubscriberIf | Abstract interface providing I/O and additional subscription facilities for a repository |
►Crtctk::componentFramework::OldbIf | Base interface for all OLDB adapters |
Crtctk::componentFramework::OldbAdapter | Implementation of the OLDB Adapter |
►Crtctk::componentFramework::OldbAdapterLegacy | Provides access to the OLDB to read and write datapoints |
Crtctk::componentFramework::RuntimeRepoAdapterLegacy | Implementation of the Runtime Configuration Repository backed by the OLDB |
Crtctk::componentFramework::test::FakeOldbIf | Implementation of a fake of OldbIf for testing |
►Crtctk::componentFramework::RuntimeRepoIf | Base interface for all Runtime Configuration Repository adapters |
Crtctk::componentFramework::RuntimeRepoAdapter | Implementation of the Runtime Configuration Repository Adapter |
Crtctk::componentFramework::RuntimeRepoAdapterLegacy | Implementation of the Runtime Configuration Repository backed by the OLDB |
Crtctk::componentFramework::test::FakeRuntimeRepoIf | Implementation of a fake of RuntimeRepoIf for testing |
Crtctk::componentFramework::test::MockRuntimeRepoIf | A mock of RuntimeRepoIf |
►Crtctk::componentFramework::test::FakeRepositorySubscriber | A simple fake implementation of RepositorySubscriberIf to allow testing the interactions and callbacks over this API |
Crtctk::componentFramework::test::FakeOldbIf | Implementation of a fake of OldbIf for testing |
Crtctk::componentFramework::test::FakeRuntimeRepoIf | Implementation of a fake of RuntimeRepoIf for testing |
Crtctk::componentFramework::test::MockRuntimeRepoIf | A mock of RuntimeRepoIf |
►Crtctk::componentFramework::test::FakeRepository | Implementation of an in-memory fake repository for testing |
Crtctk::componentFramework::test::FakePersistentRepoIf | Implementation of a fake of PersistentRepoIf for testing |
Crtctk::componentFramework::test::FakeRepositorySubscriber | A simple fake implementation of RepositorySubscriberIf to allow testing the interactions and callbacks over this API |
►Crtctk::componentFramework::test::MockRepository | A GoogleTest mock of RepositoryIf |
Crtctk::componentFramework::test::MockPersistentRepoIf | A mock of PersistentRepoIf |
Crtctk::componentFramework::RequestDispatcher< Adapter, Args > | |
Crtctk::componentFramework::RequestDispatcher< rtctk::componentFramework::OldbAdapterLegacy > | |
Crtctk::componentFramework::RequestDispatcher< rtctk::componentFramework::PersistentRepoAdapter > | |
Crtctk::componentFramework::RequestDispatcher< rtctk::componentFramework::test::FakeRepository > | |
Crtctk::componentFramework::RequestDispatcher< rtctk::componentFramework::test::FakeRepositorySubscriber > | |
CRequestHandler< Body, Allocator, Send > | |
Crtctk::componentFramework::RepositoryIf::Response | An object used to wait for a request to complete |
Crtctk::componentFramework::BufferMonitor< ClockType >::Result | |
Crtctk::componentFramework::DurationMonitor< ClockType >::Result | |
Crtctk::exampleDataTask::Computation::Result | |
►Crtctk::exampleDataTask::Computation::ResultIf | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::exampleDataTask::BusinessLogic | |
Crtctk::componentFramework::RepositoryIf::MetaData::ReverseIterator | Bidirectional reverse iterator returned by the rbegin/rend methods |
Crtctk::rtcSupervisor::RtcMonitor | |
Crtctk::rtcSupervisor::RtcObjectController | Class used to control multiple RtcObjects |
►Crtctk::rtcSupervisor::RtcObjectIf | Interface class for RtcObject |
Crtctk::rtcSupervisor::RtcObject | Concrete RtcObject implementation |
Crtctk::rtcSupervisor::RtcObjectInfo | Basic information necessary to construct an RtcObject |
Crtctk::componentFramework::RtcTypeInfo | |
Crtms::rtmsHeader | |
Crtms::rtmsLeader | |
Crtms::rtmsPayload | |
Crtms::rtmsTrailer | |
Crtctk::componentFramework::RtrClient | This internal class implements the basic communication and commands toward the server |
Crtctk::metadataCollector::Runnable< Super > | |
CSampleIdentifier | Unique identifier for packets of a single sample |
Crtctk::exampleTopic::ScaoLoopTopic | |
Crtctk::componentFramework::ScXmlExport | |
►Crtctk::telSub::SeqLoanerIf | Loaner interface |
Crtctk::telSub::DdsWaitSet | Implements DDS communication using FastDDS |
Crtctk::telSub::FakeDdsSubscriber | Fake DDS subscriber |
Crtctk::componentFramework::Serialiser< T > | Serialisation helper class for writing, it provides readable byte span to the RtrClient |
Crtctk::componentFramework::Serialiser< std::string > | |
Crtctk::componentFramework::ServerAliasCache | A utility class used to lookup the Server Alias for a given Data Point Path |
Crtctk::componentFramework::ServiceContainer | Container class that holds services of any type |
Crtctk::componentFramework::ServiceDiscovery | Class that implements a very basic service discovery mechanism |
►Crtctk::componentFramework::ServiceRegistryIf | Class that implements a service registry to be used by the service discovery |
Crtctk::componentFramework::ConsulServiceRegistryAdapter | Class that implements a very basic service discovery mechanism using Consul |
Crtctk::componentFramework::FileServiceRegistryAdapter | Class that implements a very basic service discovery mechanism using a file |
Crtctk::rtcSupervisor::detail::SetModesContext | Holds context necessary for processing a SetModes request to completion |
Crtctk::telSub::ShmPublisherIf::ShmError | |
Crtctk::telSub::ShmParams | Shared memory configuration parameters |
Crtctk::standaloneTools::ShmPub< TopicType, WriterType > | ShmPub parent class |
►Crtctk::standaloneTools::ShmPub< ImageTopic > | |
CExamplePixelsShmPub | |
►Crtctk::standaloneTools::ShmPub< ScaoLoopTopic > | |
CExampleShmPubScao | |
►Crtctk::telSub::ShmPublisherIf | Simple interface to class that owns the shared memory queue |
Crtctk::telSub::MockShmPublisherIf | |
Crtctk::telSub::ShmPublisher< UserTopicType, DataBlender, ShmWriter > | |
►Crtctk::standaloneTools::ShmSubscriberBase | Base class to implement all non-template methods that can be pre-compiled for the ShmSubscriber |
Crtctk::standaloneTools::ShmSubscriber< Topic, ConditionPolicy, ShmTraits > | Implements basic features for a simple shared memory subscriber program |
Crtctk::componentFramework::SmCatExport | |
►Cgsl::span | |
Crtctk::componentFramework::MatrixSpan< T > | A span referencing a 2D matrix buffer |
►Crtctk::componentFramework::State | |
Crtctk::componentFramework::StateMachine | |
Crtctk::componentFramework::StateMachineEngine | |
Crtctk::componentFramework::StatePublisher | Class used to publish state-changed-topic using MAL |
Crtctk::componentFramework::StateSubscriber | Class used to subscribe to state-changed-topic using MAL |
Crtctk::rtcSupervisor::StatusEstimator | Class for system status estimation |
Crtctk::rtcSupervisor::StatusPublisher | Class used to publish status-changed-topic using MAL |
►Crtctk::componentFramework::StdComponent | Basic life cycle for StdComponent |
Crtctk::componentFramework::RtcComponent | Basic life cycle for RtcComponent |
CStreamIdentifier | Unique identifier for packets of a single stream |
Celt::mal::ps::Subscriber< TOPIC_TYPE > | |
Crtctk::componentFramework::RepositorySubscriberIf::SubscribeRequest | A request object to pass information about datapoints to subscribe to |
Crtctk::componentFramework::RepositorySubscriberIf::Subscription | RAII wrapper class used to manage the life-time of individual subscriptions |
Crtctk::componentFramework::OldbAdapter::SubscriptionEntry | |
►CSuper | |
Crtctk::componentFramework::Loopaware< Super > | Life cycle extension to make RtcComponent Loopaware |
Crtctk::componentFramework::Measurable< Super > | Life cycle extension to make RtcComponent Measurable |
Crtctk::componentFramework::Optimisable< Super > | Life cycle extension to make RtcComponent Optimisable |
Crtctk::componentFramework::Runnable< Super > | Life cycle extension to make RtcComponent Runnable |
Crtctk::componentFramework::Suspendable< Super > | Life cycle extension to make Loopaware RtcComponent Suspendable |
Crtctk::exampleCustom::CustomLifeCycle< Super > | |
Crtctk::metadataCollector::Acquisitor< Super > | Life cycle extension for Acquisitor RtcComponent |
Crtctk::rtcSupervisor::Supervisory< Super > | Life cycle extension to make RtcComponent Supervisory |
Crtctk::telRepub::MudpiProcessorError::Synchronising | Synchronising |
►CT | |
Crtctk::componentFramework::detail::UnspecifiedNested< T > | Unspecified exception used by WrapWithNested |
►Ctesting::Test | |
►CTestOldbAdapterBase | |
CTestOldbAdapter | |
CTestOldbAdapterHierarchy | |
►CTestPersistentRepoAdapter | |
CTestPersistentRepoAdapterWithFits< T > | Test fixture for specific tests related to FITS file reading and writing |
►CTestRtrAdapterBase | |
CTestRtrAdapter | |
Crtctk::componentFramework::test::Callbacks | |
Crtctk::componentFramework::test::ExceptionInterface | |
Crtctk::componentFramework::test::GetChildren | |
Crtctk::componentFramework::test::MassiveParallelAccess | |
Crtctk::componentFramework::test::Metadata | |
►Crtctk::componentFramework::test::RepositoryIfTestSuite< T > | |
Crtctk::componentFramework::test::AdvancedOperation< T > | |
Crtctk::componentFramework::test::RepositoryIfTestSuiteLegacy< T > | A test suite for performing acceptance tests of a RepositoryIf implementation |
Crtctk::componentFramework::test::Subscription | |
Crtctk::componentFramework::test::Symlinks | |
CTestTopic | |
Crtctk::componentFramework::test::ThreadSafeQ< T > | |
Crtctk::componentFramework::Transition | |
►Cstd::true_type | |
Crtctk::componentFramework::IsAdapterIdTypeDefined< T, std::void_t< decltype(std::declval< typename T::AdapterIdType >())> > | Structure for detecting if a class declared a type called AdapterIdType using SFINAE |
Crtctk::componentFramework::IsComplexType< std::complex< T > > | Structure for detecting std::vector types using SFINAE |
Crtctk::componentFramework::IsMatrixBufferType< MatrixBuffer< T, A > > | Structure for detecting MatrixBuffer types using SFINAE |
Crtctk::componentFramework::IsMatrixSpanType< MatrixSpan< T > > | Structure for detecting MatrixSpan types using SFINAE |
Crtctk::componentFramework::IsSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types using SFINAE |
Crtctk::componentFramework::IsStdArrayType< std::array< T, N > > | Structure for detecting std::array types using SFINAE |
Crtctk::componentFramework::IsSupportedUriSchemeDefined< T, std::void_t< decltype(T::SUPPORTED_URI_SCHEME)> > | Structure for detecting if a class declared a member called SUPPORTED_URI_SCHEME using SFINAE |
Crtctk::componentFramework::IsVectorType< std::vector< T, A > > | Structure for detecting std::vector types using SFINAE |
►Cstd::conditional::type | |
Crtctk::componentFramework::IsStaticSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types of fixed size using SFINAE |
►Cstd::conditional::type | |
Crtctk::componentFramework::IsDynamicSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types of dynamic size using SFINAE |
►Cstd::conditional::type | |
Crtctk::componentFramework::HasSampleIdWithCorrectType< T, decltype(std::declval< T >().sample_id, 0)> | |
Crtctk::componentFramework::TypedEventPublisher< EventType > | An event publisher that is aware of event types |
Crtctk::componentFramework::detail::TypedEventPublisherManager | |
Crtctk::componentFramework::TypedEventService | A high-level event service API that is aware of event types |
Crtctk::componentFramework::TypedEventSubscriber< EventType > | An event subscriber that is aware of event types |
Crtctk::componentFramework::detail::TypedEventSubscriberManager | |
Crtctk::componentFramework::test::TypeMap< T > | |
Crtctk::componentFramework::test::TypeMap< MatrixBuffer< bool, A > > | |
Crtctk::componentFramework::test::TypeMap< MatrixBuffer< T, A > > | |
Crtctk::componentFramework::test::TypeMap< RtcString > | |
Crtctk::componentFramework::test::TypeMap< std::vector< bool, A > > | |
Crtctk::componentFramework::test::TypeMap< std::vector< T, A > > | |
Crtctk::telRepub::UdpReceiver | Receiving UDP data asynchronously and forwards received packets to provided packet processors |
Crtctk::telRepub::UdpReceiverCfg | Structure to hold UDP receiver's configuration |
Crtctk::telRepub::MudpiProcessorError::UnexpectedFrameId | Unexpected frame id inside a sample |
Crtctk::telRepub::MudpiProcessorError::UnexpectedSampleId | Unexpected sample id, so we need to resynchronize |
Crtctk::componentFramework::detail::UnsubscribeRequest | |
Crtctk::componentFramework::RepositorySubscriberIf::UnsubscribeRequest | A request object to pass information about datapoints to unsubscribe from |
Crtctk::componentFramework::detail::UpdateSymlinkRequest | |
Crtctk::componentFramework::PathMapper::UriResult | Result object returned by the PathToUri method |
Crtctk::componentFramework::detail::UserTypeHandler< T > | |
Crtctk::componentFramework::detail::UserTypeHandler< boost::container::vector< T, A > > | |
Crtctk::componentFramework::detail::UserTypeHandler< char[N]> | |
Crtctk::componentFramework::detail::UserTypeHandler< gsl::span< char, N > > | |
Crtctk::componentFramework::detail::UserTypeHandler< gsl::span< T, N > > | |
Crtctk::componentFramework::detail::UserTypeHandler< MatrixBuffer< bool, A > > | |
Crtctk::componentFramework::detail::UserTypeHandler< MatrixBuffer< T, A > > | |
Crtctk::componentFramework::detail::UserTypeHandler< MatrixSpan< T > > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::array< char, N > > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::array< std::array< T, M >, N > > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::array< T, N > > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::string > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::string_view > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::vector< bool, A > > | |
Crtctk::componentFramework::detail::UserTypeHandler< std::vector< T, A > > | |
Crtctk::componentFramework::detail::UserTypeHandler< T[N]> | Template specialisation for C-style arrays |
Crtctk::componentFramework::detail::UserTypeHandler< T[N][M]> | Template specialisation for C-style matrix |
Crtctk::componentFramework::RepositoryIf::MetaData::ValueProxy | Interface class to an underlying metadata value |
Crtctk::componentFramework::detail::ValueSubscribeRequest | |
Crtctk::componentFramework::RuntimeRepoAdapter::ValueSubscription | |
Crtctk::componentFramework::test::FakeRepositorySubscriber::ValueSubscription | |
►Cstd::vector | |
Crtctk::componentFramework::MatrixBuffer< float > | |
Crtctk::componentFramework::MatrixBuffer< T, A > | A buffer class representing 2D matrix data |
Crtctk::componentFramework::RequestDispatcher< Adapter, Args >::TableEntries | |
Crtctk::exampleTopic::WfsLoopBaseTopic< NSUBAPS > | |
Crtctk::exampleTopic::WfsLoopBaseTopic< N_SUBAPS > | |
Crtctk::telRepub::MudpiProcessorError::WranglerError | Wrangler Error |
Crtctk::rtcSupervisor::detail::WriteBackContext | Holds context necessary for processing a WriteBack request to completion |
Crtctk::componentFramework::detail::WriteMetaDataRequest | |
Crtctk::componentFramework::detail::WriteRequest< T > | |
Crtctk::componentFramework::RepositoryIf::WriteRequest | A request object to pass information about datapoints that should be written to the repository |
►CCiiOldbDpSubscription | |
COldbSubscription< T > | |
COldbSubscription< T > | |
►CCiiOldbInMemoryDataPointProvider | |
Crtctk::componentFramework::test::FakeRedisProvider | A fake provider that can also be used for external Redis unit testing |