▼Nelt | |
►Nconfigng | |
CCiiConfigValueConverter< RtcTypeInfo, CiiConfigInstanceNode > | |
►Nmal | |
►Nps | |
CPublisher | |
CSubscriber | |
▼Nfmt | |
Cformatter< eprosima::fastdds::dds::SampleRejectedStatusKind > | |
Cformatter< rtctk::rtcSupervisor::RtcCommand > | Formatter for RtcObject |
▼Nrtctk | |
Nclient | |
►NcomponentFramework | |
►Ndetail | |
CCreateDeleteSubscribeRequest | |
CCreateRequest | |
CCreateSymlinkRequest | |
CDeleteRequest | |
CExistsRequest | |
CGetChildrenRequest | |
CMeasureContext | Holds context necessary for processing a measure request to completion |
COptimiseContext | Holds context necessary for processing a optimise request to completion |
CPartialReadRequest | |
CPartialWriteRequest | |
CReadMetaDataRequest | |
CReadRequest | |
CTypedEventPublisherManager | |
CTypedEventSubscriberManager | |
CUnspecifiedNested | Unspecified exception used by WrapWithNested |
CUnsubscribeRequest | |
CUpdateSymlinkRequest | |
CUserTypeHandler | |
CUserTypeHandler< boost::container::vector< T, A > > | |
CUserTypeHandler< char[N]> | |
CUserTypeHandler< gsl::span< char, N > > | |
CUserTypeHandler< gsl::span< T, N > > | |
CUserTypeHandler< MatrixBuffer< bool, A > > | |
CUserTypeHandler< MatrixBuffer< T, A > > | |
CUserTypeHandler< MatrixSpan< T > > | |
CUserTypeHandler< std::array< char, N > > | |
CUserTypeHandler< std::array< std::array< T, M >, N > > | |
CUserTypeHandler< std::array< T, N > > | |
CUserTypeHandler< std::string > | |
CUserTypeHandler< std::string_view > | |
CUserTypeHandler< std::vector< bool, A > > | |
CUserTypeHandler< std::vector< T, A > > | |
CUserTypeHandler< T[N]> | Template specialisation for C-style arrays |
CUserTypeHandler< T[N][M]> | Template specialisation for C-style matrix |
CValueSubscribeRequest | |
CWriteMetaDataRequest | |
CWriteRequest | |
►Ntest | |
CAdvancedOperation | |
CCallbacks | |
CExceptionInterface | |
CFakeClock | |
CFakeOldbIf | Implementation of a fake of OldbIf for testing |
CFakePersistentRepoIf | Implementation of a fake of PersistentRepoIf for testing |
CFakeRedisProvider | A fake provider that can also be used for external Redis unit testing |
►CFakeRepository | Implementation of an in-memory fake repository for testing |
CData | |
►CFakeRepositorySubscriber | A simple fake implementation of RepositorySubscriberIf to allow testing the interactions and callbacks over this API |
CCreateDeleteSubscription | |
CValueSubscription | |
CFakeRuntimeRepoIf | Implementation of a fake of RuntimeRepoIf for testing |
CGetChildren | |
CMassiveParallelAccess | |
CMetadata | |
CMockCallbacks | |
CMockExtRedisBackend | Mock interface representing the external Redis backend |
CMockPersistentRepoIf | A mock of PersistentRepoIf |
CMockRepository | A GoogleTest mock of RepositoryIf |
CMockRuntimeRepoIf | A mock of RuntimeRepoIf |
CRepositoryIfTestSuite | |
CRepositoryIfTestSuiteLegacy | A test suite for performing acceptance tests of a RepositoryIf implementation |
CSubscription | |
CSymlinks | |
CThreadSafeQ | |
CTypeMap | |
CTypeMap< MatrixBuffer< bool, A > > | |
CTypeMap< MatrixBuffer< T, A > > | |
CTypeMap< RtcString > | |
CTypeMap< std::vector< bool, A > > | |
CTypeMap< std::vector< T, A > > | |
CAbstractEvent | Abstract Event Type that is used as a base for all events |
CAdapterCreationException | Thrown from service factory methods to indicate the adapter construction failed |
CAlertCmdsImpl | Class that handles reception of command ClearAlerts using MAL |
CAlertConflictException | Exception indicating that an alert conflicts with already known alert |
CAlertEventPublisher | Alert observer that publishes alerts to Event Channel |
CAlertInfo | |
CAlertLogger | Alert observer that publishes alerts to Log Files |
CAlertObserverIf | |
CAlertOldbPublisher | Alert observer that publishes alerts to Online Database |
CAlertService | |
CAlertServiceIf | Alert Service interface |
CAlertSource | Models a single alert source that can be set or cleared |
CAlertStatus | |
►CAlertStatusEvent | Event published when alert status is changed |
CAlert | Represents an active alert originating from a component instance |
CAlertUnknownException | Exception indicating that an alert does not exist |
CArgs | Class used to parse default command line arguments |
CAsSpan | Gets the span type for converting type T to a span |
CAsSpan< const std::array< T, Size > > | |
CAsSpan< MatrixBuffer< T, Allocator > > | |
CAsSpan< std::array< T, Size > > | |
CAsSpan< std::vector< T, Allocator > > | |
►CBufferManager | BufferManager is a class that will allocate a big buffer and spit it up in several cache-aligned sub-buffers |
CBufferReference | |
►CBufferMonitor | Monitors min, mean and max occupation of a buffer and publishes them to OLDB |
CResult | |
CBufferTooSmall | The BufferTooSmall is thrown when an API call fails because the provided buffer is not big enough to hold the data |
CCommandReplier | Class that handles reception of commands using MAL |
CCommandRequestor | Extendable class that allows to send commands to components using MAL |
►CComponentMetrics | Implementation of ComponentMetricsIf |
CParameters | Runtime parameters |
CComponentMetricsIf | Component metrics interface |
CComputationEvent | Abstract Event Type that is used as a base for computation events |
CComputationFinishedEvent | Event Type used to signal that a computation has finished |
CComputationStartedEvent | Event Type used to signal that a computation has started |
CConfigurationEvent | Abstract Event Type that is used as a base for configuration events |
CConfigurationRetrievedEvent | Event Type used to signal that a configuration data item was retrieved from RTR |
CConfigurationUpdatedEvent | Event Type used to signal that a configuration data item was updated in RTR |
CConsulServiceRegistryAdapter | Class that implements a very basic service discovery mechanism using Consul |
CCoordinationEvent | Abstract Event Type that is used as a base for coordination events |
CCounterMetricInfo | Defines auxiliary information associated with each counter registered with ComponentMetricsIf |
CCsvDataRecorder | Recorder used for writing data to a CSV file |
►CDataPointPath | This class provides a wrapper for a data point path |
CInvalidPathException | Exception class used when an invalid character is used in a DataPointPath |
CDataPointRecordingUnit | Recording Unit that can record datapoints |
►CDataRecorder | This is an abstract class that can be used to implement an OutputStage for a Recording Unit |
CColumnMetaData | |
CDds | Common functionallty needed to create DDS entities like participant and topic that can be later used (extent) for DDS data publishing and subscribing |
CDdsPub | All functionallty needed to create DDS entities for DDS data publishing is concentrated in this class |
CDdsReaderListener | Listener class for different DDS events |
CDdsReaderParams | Structure that keeps together topic name and DDS Data Writer listener |
CDdsSub | All functionality needed to create DDS entities for DDS data subscribing is concentrated in this class |
CDdsWriterListener | Listener class for differetn DDS events |
CDdsWriterParams | Structure that keeps together topic name and DDS Data Writer listener |
CDdtError | This Exception is raised when the DDT Publisher returns an error that cannot be handled by the DDT Sink |
CDdtSinkNotFound | This Exception is raised when an invalid ddt sink is requested |
CDebugExport | |
CDeserialiser | Deserialisation helper class for reading, it provides a writable byte span to the RtrClient |
CDeserialiser< std::string > | |
►CDurationMonitor | Monitors min, mean and max duration and publishes them to OLDB |
CResult | |
CDynamicDataPointRecordingUnit | 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 |
CEventPublisherIf | Interface class for publishing JSON events |
CEventServiceIf | Interface class for providing pub/sub facilities for JSON events |
CEventSubscriberIf | Interface class for subscribing to JSON events |
►CFactoryRegistry | A simple registry of various factory objects |
CFactoryIf | The base class for all factory objects that are registered in the FactoryRegistry |
CFakeComponentMetrics | |
CFileServiceRegistryAdapter | Class that implements a very basic service discovery mechanism using a file |
CFitsColumn | |
CFitsColumnFormat | Type that stores type information for a FITS TFORM string |
CFitsColumnFormat< bool > | |
CFitsColumnFormat< double > | |
CFitsColumnFormat< float > | |
CFitsColumnFormat< int16_t > | |
CFitsColumnFormat< int32_t > | |
CFitsColumnFormat< int64_t > | |
CFitsColumnFormat< int8_t > | |
CFitsColumnFormat< std::string > | |
CFitsColumnFormat< T, typename std::enable_if< IS_DYNAMIC_SPAN_TYPE< T > >::type > | |
CFitsColumnFormat< T, typename std::enable_if< IS_MATRIX_BUFFER_TYPE< T > >::type > | |
CFitsColumnFormat< T, typename std::enable_if< IS_STATIC_SPAN_TYPE< T > >::type > | |
CFitsColumnFormat< T, typename std::enable_if< IS_STD_ARRAY_TYPE< T > >::type > | |
CFitsColumnFormat< T, typename std::enable_if< IS_VECTOR_TYPE< T > >::type > | |
CFitsColumnFormat< uint16_t > | |
CFitsColumnFormat< uint32_t > | |
CFitsColumnFormat< uint64_t > | |
CFitsColumnFormat< uint8_t > | |
CFitsDataRecorderFitsError | |
CFitsRecorder | |
CFrequencyEstimator | Estimates the frequency in which Tick is called and publishes result to OLDB |
CFuncCmdsImpl | Class that handles reception of commands Run, Idle and Recover using MAL |
CHasSampleIdWithCorrectType | |
CHasSampleIdWithCorrectType< T, decltype(std::declval< T >().sample_id, 0)> | |
CHrtcConfigurationAppliedEvent | Event Type used to signal that a configuration data item was applied in HRTC |
CHrtcConfigurationScheduledEvent | Event Type used to signal that a configuration data item was scheduled to be applied in HRTC |
CHrtcStateChangedEvent | Event Type used to signal that some entity in HRTC changed its state |
CInitialisationException | Thrown in cases where an initialisation routine has failed |
CIntrospectionImpl | Class that handles reception of introspection commands |
CInvalidArgumentException | Thrown if an argument passed to a method was invalid |
CInvalidSetting | This Exception is raised when a invalid setting was used in the runtime repo |
CInvalidStateChange | This Exception is raised when the state change requested is invalid |
CIpcqError | This Exception is raised when the ipc queue returns an error that cannot be handled by the Telemetry Source Thread |
CIpcqRecordingUnit | Recording Unit that can record from shared memory queue |
Cis_base_of_template_impl | |
CIsAdapterIdTypeDefined | Structure for detecting if a class declared a type called AdapterIdType using SFINAE |
CIsAdapterIdTypeDefined< T, std::void_t< decltype(std::declval< typename T::AdapterIdType >())> > | Structure for detecting if a class declared a type called AdapterIdType using SFINAE |
CIsComplexType | Structure for detecting std::vector types using SFINAE |
CIsComplexType< std::complex< T > > | Structure for detecting std::vector types using SFINAE |
CIsDynamicSpanType | Structure for detecting gsl::span types of dynamic size using SFINAE |
CIsDynamicSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types of dynamic size using SFINAE |
CIsMatrixBufferType | Structure for detecting MatrixBuffer types using SFINAE |
CIsMatrixBufferType< MatrixBuffer< T, A > > | Structure for detecting MatrixBuffer types using SFINAE |
CIsMatrixSpanType | Structure for detecting MatrixSpan types using SFINAE |
CIsMatrixSpanType< MatrixSpan< T > > | Structure for detecting MatrixSpan types using SFINAE |
CIsSpanConvertible | Type trait to check if a type can be converted to a Span using AsSpan/ToSpan |
CIsSpanType | Structure for detecting gsl::span types using SFINAE |
CIsSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types using SFINAE |
CIsStaticSpanType | Structure for detecting gsl::span types of fixed size using SFINAE |
CIsStaticSpanType< gsl::span< T, N > > | Structure for detecting gsl::span types of fixed size using SFINAE |
CIsStdArrayType | Structure for detecting std::array types using SFINAE |
CIsStdArrayType< std::array< T, N > > | Structure for detecting std::array types using SFINAE |
CIsSupportedUriSchemeDefined | Structure for detecting if a class declared a member called SUPPORTED_URI_SCHEME using SFINAE |
CIsSupportedUriSchemeDefined< T, std::void_t< decltype(T::SUPPORTED_URI_SCHEME)> > | Structure for detecting if a class declared a member called SUPPORTED_URI_SCHEME using SFINAE |
CIsVectorType | Structure for detecting std::vector types using SFINAE |
CIsVectorType< std::vector< T, A > > | Structure for detecting std::vector types using SFINAE |
CJsonEventRecordingUnit | Recording Unit that can record JSON events |
CLogInfo | |
CLogInitializer | RAII class to clean-up logging without leaking memory |
►CLoopaware | Life cycle extension to make RtcComponent Loopaware |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CLoopCmdsImpl | Class that handles reception of commands Open and Close using MAL |
CMalDdsEventPublisher | Implementation of event publisher |
CMalDdsEventService | Implementation of low-level event service using CII MAL DDS as middleware |
CMalDdsEventSubscriber | Implementation of event subscriber |
CMatrixBuffer | A buffer class representing 2D matrix data |
CMatrixSpan | A span referencing a 2D matrix buffer |
CMeasCmdsImpl | Class that handles reception of command Measure using MAL |
►CMeasurable | Life cycle extension to make RtcComponent Measurable |
CBizLogicIf | Business logic interface for Measurable mixin |
CInputStage | |
CModelBuilder | |
COutputStage | |
CMetricConflictException | Exception indicating that a metric such as counter or thread conflicts with already known metrics |
CMockComponentMetrics | |
CModelBuilderBase | Base class of the ModelBuilder |
CModelManipulator | Class that provides methods to manipulate the state machine model |
CNestedExceptionPrinter | Adapter object intended to be used in contexts without direct access to the output-stream object |
CNoBufferAvailableException | |
CNotImplementedException | The NotImplementedException is thrown whenever an attempt is made to use a feature or function that has not been implemented |
►COldbAdapter | Implementation of the OLDB Adapter |
CSubscriptionEntry | |
COldbAdapterLegacy | Provides access to the OLDB to read and write datapoints |
COldbIf | Base interface for all OLDB adapters |
COptCmdsImpl | Class that handles reception of command Optimise using MAL |
►COptimisable | Life cycle extension to make RtcComponent Optimisable |
CBizLogicIf | Business logic interface for Optimisable mixin |
CInputStage | |
CModelBuilder | |
COutputStage | |
►CPathMapper | Used to calculate URIs from datapoint paths |
CFilePathResult | Result object returned by the PathToFile method |
CUriResult | Result object returned by the PathToUri method |
►CPersistentRepoAdapter | Implements the Persistent Configuration Repository adapter that uses the CII configuration service as the backend |
CInvalidDocumentException | Exception indicating that validation checks of a CII configuration document failed |
CPathMissingException | Exception indicating a datapoint path does not exist |
CServiceFailureException | Exception indicating a general CII configuration service error |
CPersistentRepoIf | Base interface for all Persistent Configuration Repository adapters |
CPlantUmlExport | |
►CPopulateConfig | A utility class used to populate the Runtime Configuration Repository |
CInvalidConfigException | The InvalidConfigException is thrown when configuration errors are found in the Persistent Configuration Repository |
CInvalidDataPointException | The InvalidDataPointException is thrown when datapoints in the Persistent Configuration Repository are discovered to have invalid values |
CRepositoryServiceException | The RepositoryServiceException is thrown when unexpected problems arise accessing the underlying repository service |
►CPythonInterpreter | Helper class for managing the lifecycle of an embedded Python interpreter |
CSetupFailure | This exception is raised when the Python interpreter cannot be initialised properly |
CRecordingInfo | |
CRecordingInfo< AlertStatusEvent > | Trait class that defines how AlertStatusEvent is recorded |
CRecordingInfo< ComputationEvent > | Trait class that defines how ComputationEvent is recorded |
CRecordingInfo< ComputationFinishedEvent > | Trait class that defines how ComputationFinishedEvent is recorded |
CRecordingInfo< ComputationStartedEvent > | Trait class that defines how ComputationStartedEvent is recorded |
CRecordingInfo< ConfigurationEvent > | Trait class that defines how ConfigurationEvent is recorded |
CRecordingInfo< ConfigurationRetrievedEvent > | Trait class that defines how ConfigurationRetrievedEvent is recorded |
CRecordingInfo< ConfigurationUpdatedEvent > | Trait class that defines how ConfigurationUpdatedEvent is recorded |
CRecordingInfo< CoordinationEvent > | Trait class that defines how CoordinationEvent is recorded |
CRecordingInfo< HrtcConfigurationAppliedEvent > | Trait class that defines how HrtcConfigurationAppliedEvent is recorded |
CRecordingInfo< HrtcConfigurationScheduledEvent > | Trait class that defines how HrtcConfigurationScheduledEvent is recorded |
CRecordingInfo< HrtcStateChangedEvent > | Trait class that defines how HrtcStateChangedEvent is recorded |
CRecordingInfo< StateChangedEvent > | Trait class that defines how StateChangedEvent is recorded |
CRecordingUnit | Abstract base class for all sources that can be recorded by the MetadataCollector and TelemetryRecorder |
CRecoverCmdsImpl | Class that handles reception of command Recover using MAL |
CRegisterFactory | A helper class used to perform registration and deregistration of a factory |
CRepositoryFactory | A base class for factories that create instances of repository adapters from URIs |
►CRepositoryIf | Abstract interface providing basic read and write facilities to a repository |
CAccessOutOfBounds | |
CBatchRequest | An object representing one or more asynchronous I/O requests to a repository |
CBatchResponse | |
CBufferTooSmall | |
CDataPointAlreadyExists | |
CDataPointDoesNotExist | |
CIncompatibleType | |
►CMetaData | Class for passing/receiving metadata to/from the repository |
CConstIterator | Constant version of the bidirectional forward iterator returned by the cbegin/cend methods |
CConstReverseIterator | Constant version of the bidirectional reverse iterator returned by the crbegin/crend methods |
CConstValueProxy | A read-only interface class to an underlying metadata value |
CIterator | Bidirectional forward iterator returned by the begin/end methods |
CKeyAlreadyExists | Exception indicating that the metadata already contains the given key |
CKeyDoesNotExist | Exception indicating that the given key does not exist in the metadata |
CReverseIterator | Bidirectional reverse iterator returned by the rbegin/rend methods |
CTypeMismatch | Exception indicating that a value with the wrong type was being assigned to a reserved key |
CUnsupportedType | Exception indicating that an unsupported type was used for the metadata value |
CValueProxy | Interface class to an underlying metadata value |
►CMultipleRequestsFailed | |
CInfo | |
COperationNotAllowed | |
►CReadRequest | A request object to pass information about datapoints that should be read from the repository |
CParameters | A structure to hold the arguments passed with one of the Add methods |
CResponse | An object used to wait for a request to complete |
CServiceFailure | |
CUnsupportedType | |
►CWriteRequest | A request object to pass information about datapoints that should be written to the repository |
CParameters | A structure to hold the arguments passed with one of the Add methods |
►CRepositorySubscriberIf | Abstract interface providing I/O and additional subscription facilities for a repository |
CBatchRequest | |
CSequenceIdMissmatch | |
►CSubscribeRequest | A request object to pass information about datapoints to subscribe to |
CParameters | A structure to hold the arguments passed to the Add method |
CSubscription | RAII wrapper class used to manage the life-time of individual subscriptions |
CSubscriptionError | |
►CUnsubscribeRequest | A request object to pass information about datapoints to unsubscribe from |
CParameters | A structure to hold the arguments passed with one of the Add methods |
CRequestAborted | Thrown if somebody sent a stop or abort command |
►CRequestDispatcher | |
CTableEntries | |
CRequestFailed | Thrown if the command was accepted but the task to run failed |
CRequestRejected | Thrown if a command is not allowed in current state or guard |
►CRtcComponent | Basic life cycle for RtcComponent |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CRtctkException | Base class for all Rtctk exceptions |
CRtcTypeInfo | |
CRtrClient | This internal class implements the basic communication and commands toward the server |
►CRunnable | Life cycle extension to make RtcComponent Runnable |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
►CRuntimeRepoAdapter | Implementation of the Runtime Configuration Repository Adapter |
CCreateDeleteSubscription | |
CValueSubscription | |
CRuntimeRepoAdapterLegacy | Implementation of the Runtime Configuration Repository backed by the OLDB |
CRuntimeRepoIf | Base interface for all Runtime Configuration Repository adapters |
CScXmlExport | |
CSerialiser | Serialisation helper class for writing, it provides readable byte span to the RtrClient |
CSerialiser< std::string > | |
CServerAliasCache | A utility class used to lookup the Server Alias for a given Data Point Path |
CServiceContainer | Container class that holds services of any type |
CServiceDiscovery | Class that implements a very basic service discovery mechanism |
►CServiceRegistryIf | Class that implements a service registry to be used by the service discovery |
CConsulUnavailable | |
CInvalidComponent | |
CInvalidService | |
CSmCatExport | |
CState | |
CStateChangedEvent | Event Type used to signal that some entity changed its state |
CStateMachine | |
CStateMachineEngine | |
CStatePublisher | Class used to publish state-changed-topic using MAL |
CStateSubscriber | Class used to subscribe to state-changed-topic using MAL |
CStdCmdsImpl | Class that handles reception of stdif commands |
►CStdComponent | Basic life cycle for StdComponent |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CStdIfRequestAborted | Thrown if somebody sent a stop or abort command |
CStdIfRequestFailed | Thrown if the command was accepted but the task to run failed |
CStdIfRequestRejected | Thrown if the command is not allowed in current state or guard |
CSuspCmdsImpl | Class that handles reception of commands Suspend and Resume using MAL |
►CSuspendable | Life cycle extension to make Loopaware RtcComponent Suspendable |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CThreadActivity | Class that handles state machine activities |
CTransition | |
CTypedEventPublisher | An event publisher that is aware of event types |
CTypedEventRecordingUnit | Recording Unit that can record typed events |
CTypedEventService | A high-level event service API that is aware of event types |
CTypedEventSubscriber | An event subscriber that is aware of event types |
CUnsupportedTypeException | The UnsupportedTypeException is thrown whenever an attempt is made to use an unsupported type in the RTC Toolkit API |
CUnsupportedUriException | The UnsupportedUriException is thrown whenever an attempt is made to use an unsupported URI in the RTC Toolkit API |
CUpdateCmdsImpl | Class that handles reception of command Update using MAL |
►NdataTask | |
CComputationBase | Base class for Data Task computations |
►NddtServer | |
CBusinessLogic | 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 |
CDdtForwarder | Base class defining common interface for all DDT forwarders |
CDdtPublisherImage1d | DDT Publisher class used to publish one-dimensional DDT streams |
CDdtPublisherImage2d | DDT Publisher class used to publish two-dimensional DDT streams |
CIpcqDdtForwarder | DDT Forwarder unit that ingests data from from SHM and republishes it on several DDT streams |
►NdeploymentDaemon | |
CDeploymentAlreadyExists | Thrown if the command is not allowed because there is already deployment (= in Deployment State) |
CDeploymentCmdsImpl | Class that handles reception of DeploymentCmds commands |
►CDeploymentDaemonBusinessLogic | Deployment Daemon business logic |
CPythonObjects | |
►CDeploymentDaemonLifeCycle | Life cycle for DeploymentDaemonComponent |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CDeploymentDaemonRequestAborted | Thrown if somebody sent a stop or abort command |
CDeploymentDaemonRequestFailed | Thrown if the command was accepted but the task to run failed |
CDeploymentDaemonRequestRejected | Thrown if the command is not allowed in current state |
CLogInfoImpl | Implementation of LogInfo structure for Deployment Daemon defined in ICD |
CNoDeployment | Thrown if the command is not allowed because there is no deployment (=not in Deployment State) |
►NexampleComponent | |
CBusinessLogic | |
►NexampleCustom | |
CBusinessLogic | |
CCustomCmdsImpl | |
►CCustomLifeCycle | |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
►NexampleDataTask | |
CBusinessLogic | |
►CComputation | |
CResult | |
CResultIf | |
►NexampleTopic | |
CLgsPixelTopic | |
CMcaoLoopTopic | |
CPixelBaseTopic | |
CPixelSuperTopic | |
CScaoLoopTopic | |
CWfsLoopBaseTopic | |
►NmetadataCollector | |
►CAcquisitor | Life cycle extension for Acquisitor RtcComponent |
CBizLogicIf | |
CInputStage | |
CModelBuilder | |
COutputStage | |
CAcquisitorCmdsImpl | Class that handles reception of metadaqif commands using MAL |
CBusinessLogic | Business logic class for the Metadata Collector |
CCommandRequestor | |
CDaqReply | |
CDaqRequestRejected | Thrown if command is not allowed in current state or guard |
CDaqStatus | |
CDaqStopReply | |
CLoopaware | |
CRunnable | |
►NmudpiPub | |
CAppCfg | Configuration of entire MUDPI Publisher application |
CBusinessLogic | |
CPubCfg | Configuration (Dynamic + Static) of a single MUDPI Publisher object |
CPubDynamicCfg | Dynamic Configuration of a single MUDPI Publisher object |
CPublisher | |
CPubStaticCfg | Static Configuration of a single MUDPI Publisher object |
►NrtcSupervisor | |
►Ndetail | |
CSetModesContext | Holds context necessary for processing a SetModes request to completion |
CWriteBackContext | Holds context necessary for processing a WriteBack request to completion |
CAlertAggregator | Class for system status estimation |
CCommandFailedException | Dedicated exception type to indicate errors |
CModeCmdsImpl | Class that handles reception of mode-related commands using MAL |
CRtcMonitor | |
CRtcObject | Concrete RtcObject implementation |
CRtcObjectController | Class used to control multiple RtcObjects |
CRtcObjectIf | Interface class for RtcObject |
CRtcObjectInfo | Basic information necessary to construct an RtcObject |
CRtcSupervisor | |
CStatusEstimator | Class for system status estimation |
CStatusPublisher | Class used to publish status-changed-topic using MAL |
►CSupervisory | Life cycle extension to make RtcComponent Supervisory |
CBizLogicIf | Business logic interface for Supervisory mixin |
CInputStage | |
CModelBuilder | |
COutputStage | |
CWriteBackCmdsImpl | Class that handles reception of writeback-related commands using MAL |
►NstandaloneTools | |
CGenDdsPublisher | 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 |
CGenRtrWriter | 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 |
CGenRtrWriterBase | Base class for Generic RTR Writer |
CShmPub | ShmPub parent class |
CShmSubscriber | Implements basic features for a simple shared memory subscriber program |
CShmSubscriberBase | Base class to implement all non-template methods that can be pre-compiled for the ShmSubscriber |
►NtelemetryRecorder | |
CBusinessLogic | Business Logic implementation for a Telemetry Recorder instance |
►NtelRepub | |
CCfgMudpiProc | Structure to hold MudpiProcessor's configuration |
CCfgPubThread | Structure to hold PubThread's configuration |
CCfgPubThreadMudpi | Structure to hold PubThreadMudpi's configuration |
CErrorCode | |
CMudpiProcessor | Processing MUDPI data received by UDP receiver: rtctk::telRepub::UdpReceiver |
►CMudpiProcessorError | MUDPI Processor errors |
CChecksumError | MUDPI Checksum error |
CFrameIdOutOfRange | FrameId out of range |
CPacketSizeError | (UDP) Packet Size error |
CSynchronising | Synchronising |
CUnexpectedFrameId | Unexpected frame id inside a sample |
CUnexpectedSampleId | Unexpected sample id, so we need to resynchronize |
CWranglerError | Wrangler Error |
CPacketFrame | |
CPubThread | DDS publisher thread class that supports production and simulation mode |
CPubThreadMudpi | DDS publisher thread class that supports (re)publishing of MUDPI samples |
CPubThreadSim | DDS publisher thread class that supports simulation mode |
CTelRepubBusinessLogic | Telemetry Republisher business logic |
CUdpReceiver | Receiving UDP data asynchronously and forwards received packets to provided packet processors |
CUdpReceiverCfg | Structure to hold UDP receiver's configuration |
►NtelSub | |
NCorrelationStatus | |
CAgnosticDataSamples | Container of DDS samples and associated sample information |
CBusinessLogic | Implements the Telemetry Subscriber business logic |
CCorrelationFailedError | |
CCorrelator | Implements a correlator |
CCorrelatorIf | Interface for correlator implemementations that takes new data samples from DDS and performs correlation on them |
CCorrelatorParams | Placeholder for correlator parameters |
CDataSamplesView | A set of correlated agnostic non-owning data samples references |
CDataSampleView | Agnostic data sample non-owning reference type |
CDdsParams | Parameter set to be passed to classes deriving from DdsWaitSetIf |
CDdsReaderListener | Listener class for different DDS events |
CDdsTopicOptions | Options for a single topic |
CDdsWaitSet | Implements DDS communication using FastDDS |
CDdsWaitSetError | Error reporting struct, contains the return code and topic where the error occurred |
CDdsWaitSetIf | Base class abstracting DDS communication code |
CFakeDdsSubscriber | Fake DDS subscriber |
CMockCorrelatorIf | |
CMockDdsWaitSet | |
CMockShmPublisherIf | |
COperationalLogic | Implements the behaviour for Operational state |
COperationalLogicFactoryParams | Set of all parameters needed when constructing the OperationalLogic object |
►COperationalLogicIf | Interface to the operational logic implementation |
CLastError | Describes last errors |
COperationalParams | Configuration parameters needed for operational logic |
CSeqLoanerIf | Loaner interface |
CShmParams | Shared memory configuration parameters |
CShmPublisher | |
►CShmPublisherIf | Simple interface to class that owns the shared memory queue |
CBlenderError | |
CShmError | |
▼Nrtms | RTMS header definition |
CrtmsHeader | |
CrtmsLeader | |
CrtmsPayload | |
CrtmsTrailer | |
Nstdif | |