All Classes and Interfaces

Class
Description
Skeleton implementation for algorithms conforming to the XTCE Algorithm definition.
stubbed implementation of DataDecoder that "removes" all the AlgorithmExecutor methods - to be used until the data decoders will work as algorithms, or for data decoders that do not need any input parameters
stubbed implementation of DataEncoder that "removes" all the AlgorithmExecutor methods - to be used until the data decoders will work as algorithms, or for data decoders that do not need any input parameters
 
Default implementation of an EventProducer that provides shortcut methods for sending message of different severity types.
Abstract class for MDB loaders that load data from files (or directories with files)
 
Base class for an AuthModule that identifies users based on an incoming HTTP request.
Data holder for passing an HttpRequest to a login call.
An HTTP-specific subservice whose lifecycle is managed by HttpServer.
 
Abstract link implementation as a Service handling the basic enable/disable getConfig operations and data in/out counts
 
This class provides some common facilities for the packet preprocessors.
 
 
 
 
 
Iterator through a table.
Base implementation for a TC data link that initialises a post processor and implements basic methods.
Sends TC as TC frames (CCSDS 232.0-B-3) or TC frames embedded in CLTU (CCSDS 231.0-B-3).
Base class for TM/TC/parameter links.
Abstract link that starts a thread when it's enabled and stops it when it's disabled.
 
 
 
Protobuf type AccountCollection
Protobuf type AccountCollection
 
Protobuf type AccountRecord
 
Protobuf type AccountRecord
 
Meta information for a globally available acknowledgment.
 
 
 
 
 
 
 
 
Keeps track of the alarm for one parameter or event.
This class stores some info related to one active algorithm
A command which is just being sent (maybe in the queue) or that has been sent and command verifiers are pending.
 
 
 
 
Protobuf type ActivityDefinition
Protobuf type ActivityDefinition
 
 
An executor capable of executing any amount of activities of a specified type.
 
 
 
 
 
 
 
Schedules activities in the timeline
Yamcs service for executing activities.
 
 
 
A data link that has multiple sub-links
Expressions containing aggregates are computed in two phases: phase 1: the input tuples are passed to a list of expressions composed by the group by columns and the list of aggregates phase 2: the output tuples of phase 1 are passed to the list of original select list.
 
 
Token literal values and constants.
Token Manager.
operations to aggregates or arrays
 
 
builds aggregate or array values out of members extracted from the parameter archive.
Iterates over parameter archive segments storing components of an aggregate or array value and reconstructs the aggregate/array value from those components.
 
 
Records alarms.
Generates events for parameters out of limits.
 
Used by AlarmServer to indicate that a specified alarm instance does not have the expected sequence number.
Maintains a list of active alarms.
Inspired from ANSI/ISA–18.2 Management Of Alarm Systems For The Process Industries process is the entity that triggers the alarm, in our case parameters or events.
 
Handles algorithms for one language.
exception thrown when unexpected things happen during the loading and execution of algorithms.
 
A context is a collection of active algorithms.
Describes the result of the algorithm execution, which consists of the following components: Input Parameter Values (Optional) - A list of parameters that were used as input to the algorithm. Output Parameter Values - A list of ParameterValue objects that are propagated to Yamcs clients.
Represents the execution context of one algorithm.
Responsible for creating algorithm executors.
Library of functions available from within Algorithm scripts using this naming scheme:
Manages the provision of requested parameters that require the execution of one or more XTCE algorithms.
 
 
 
 
Alter table supports only ALTER TABLE <name> RENAME TO <new_name>
 
 
Decodes frames as per CCSDS 732.0-B-3
Reed-Solomon (10, 6) encoding/decoding as specified in CCSDS RECOMMENDED STANDARD FOR AOS SPACE DATA LINK PROTOCOL CCSDS 732.0-B-3 September 2015 4.1.2.6 Frame Header Error Control
 
 
AOS Transfer Frame as per CCSDS RECOMMENDED STANDARD FOR AOS SPACE DATA LINK PROTOCOL CCSDS 732.0-B-3 September 2015 Primary Header is composed of Transfer frame version number (2 bits) - shall be set to 01 Spacecraft id (8 bits) Virtual Channel id (6 bits) Virtual Channel frame count (24 bits) replay flag (1 bit) VC frame count usage flag (1 bit) spare (2 bits) VC frame count cycle frame header error control (optional)
 
Identifies logins based on an API key, this should be used only for calling programs.
Credentials for identifying as an application, for example the singleton application that represents a service account.
 
This corresponds to an ?
Handles conversions from engineering value to raw value according to the parameter type and encoding
 
 
 
This is another implementation of the parameter cache using arrays to store primitive values (instead of storing Value).
Multidimensional value array.
wrapper around a rocksdb iterator that only supports next() and is restricted to a range.
 
 
 
 
 
 
 
 
Thrown when an AuthModule failed to perform the authentication process (backend not available, password does not match, ...).
Data holder for information related to a verified authentication attempt.
Tag interface that represent any kind of token submitted during login for identifying an application or user.
Adds servers-side support for OAuth 2 authorization flows for obtaining limited access to API functionality.
Interface implemented by the Authentication and Authorization modules.
Thrown when an AuthModule failed to perform the authorization process.
Collection of roles, system and/or object privileges.
Back-fills the parameter archive by triggering replays: - either regularly scheduled replays - or monitor data streams (tm, param) and keep track of which segments have to be rebuild
 
Command line backup utility for yamcs.
JMX MBean for performing a hot backup of a tablespace.
 
 
When there were errors in interpreting the request
this is a copy of the message defined in the API but we define it separately so we can make the two different in the future if required
this is a copy of the message defined in the API but we define it separately so we can make the two different in the future if required
Protobuf type BandFilter.FilterCriterion
Protobuf type BandFilter.FilterCriterion
 
Protobuf type BandFilter.ItemFilter
Protobuf type BandFilter.ItemFilter
 
 
 
Base class for all segments of values, timestamps or ParameterStatus
Base for spreadsheet loader - this contains common properties for both V6 and V7 loaders.
 
Temporary value holder for the enumeration definition; needed because enumerations are read before parameters, and reading sharing the same EPT among all parameters is not a good approach (think different alarm definitions)
 
Parses a directory listing from a linebreak separated list of filenames Directories are detected when the file name ends with a directory terminator
Holds the value of a parameter.
Makes CLTUs from command transfer frames as per CCSDS 231.0-B-3 (TC SYNCHRONIZATION AND CHANNEL CODING)
 
 
 
 
Allows to read and write bits from a byte array (byte[]) keeps a bit position and the extractions are relative to the position.
Decoder that returns a boolean true if the read bytes has all bits set of the provided bit mask.
Bitpacking routines
BitReader is a wrapper around the ByteBuffer that allows to read individual bits.
 
 
Wrapper around a ByteBuffer that allows to write individual bits or group of bits All the writings/readings are performed to a temporary long which is stored into the backing ByteBuffer when it is "full" Don't forget to call flush after the last write, such that the long is written to the backing ByteBuffer
A HttpHandler that allows request bodies.
an array that stores the bits in a long[] - each long stores 64 values
 
Boolean value sgement uses a boolean array backed by a long[] to represent the boolean values as a set of bits
 
 
 
byte array which grows and also supports writing/reading int, double, etc.
 
 
Wrapper around byte array that allows usage as hashmap keys
Interface describing a CODEC to compress integers to bytes.
 
 
Observes the state of a single RPC call where both request and response are non-streaming.
A Cancel.request is a primitive that requests a certain transaction canceled*
decodes raw frame data according to according to CCSDS 131.0-B-3.
CCSDS Packet as per CCSDS 133.0-B-2 https://public.ccsds.org/Pubs/133x0b2e1.pdf
Reads CCSDS packets from an input stream: first it reads 6 bytes primary header, it derives the length from the last two bytes and reads the remaining of the data.
Contains some helper methods for all the pre-processors for CCSDS packets
Fills in the time, seq and checksum
Completeness index of CCSDS telemetry.
 
 
 
 
 
 
 
CFDP packet reader that splits the stream into packets based on the length of the packet
 
Implements CCSDS File Delivery Protocol (CFDP) in Yamcs.
 
 
CFS TC packets: CCSDS primary header - 6 bytes.
Generate Yamcs events out of cFS event packets
Preprocessor for the CFS TM packets: CCSDS primary header 6 bytes Time seconds 4 bytes subseconds(1/2^16 fraction of seconds) 2 bytes Options:
 
 
 
A CLCW stream is a stream used to pass the CLCW (Command Link Control Word - see CCSDS 232.0-B-3) between the receiver and the FOP1 processor.
Protobuf type Clearance
Protobuf type Clearance
 
 
 
 
Makes CLTUs from command transfer frames as per CCSDS 231.0-B-3 (TC SYNCHRONIZATION AND CHANNEL CODING)
 
 
Protobuf type Assignment
Protobuf type Assignment
Protobuf type AssignmentInfo
Protobuf type AssignmentInfo
 
 
 
 
Represents a column in a query, for example x and y below: select x from table where y > 0
Protobuf type ColumnInfo
Protobuf type ColumnInfo
 
 
Serializes column values to byte arrays (used as part of tables) and back
 
serializers for table format version ≤ 2 where the signed integers (and timestamps) are stored as they are and do not sort properly when they are primary keys.
 
Used in partitioning by value - translates between value (Object) and byte[]
This represents a command together with its options and subcommands
 
 
 
Interface implemented by all the classes that want to receive command history events.
 
Interface implemented by all classes that provide command history to the CommandHistoryRequestManager
Used by the commanding applications to save commands and commands acknowledgements into a history.
provides acknowledgment status during execution of command
Records command history the key is formed by generation time, origin and sequence number the value is formed by a arbitrary number of attributes
Performs replays for command history
Part of processors: handles filtered requests for command history.
Responsible for parsing and tc packet composition.
Implements the "commands" timeline source providing items derived from the command history.
 
A command option.
 
 
The command post processor is responsible to provide the binary packet that will be send out for a PreparedCommand.
 
 
Implements the management of the control queues for one processor: for each command that is sent, based on the sender it finds the queue where the command should go depending on the queue state the command can be immediately sent, stored in the queue or rejected when the command is immediately sent or rejected, the command queue monitor is not notified if the command has transmissionConstraints with timeout > 0, the command can sit in the queue even if the queue is not on hold Note: the update of the command monitors is done in the same thread.
Object that is used to persist link state information across Yamcs restarts.
 
This is responsible for "releasing" a command.
 
 
 
 
 
This class implements the (post transmission) command verification.
 
 
 
 
 
 
 
 
Represents a past CfdpFileTransfer obtained from the database.
 
used by the SpreadsheetLoader to parse conditions
 
 
Represents a type of configuration file
Exception thrown if there is an error in configuration.
Specifically intended for short-term console output.
 
this is no compiled expression at all, it just returns the same value
Use this in the consumers to signal that they don't want anymore data.
 
 
Holds the definition of a container, the content of its slice and some positioning information inside that slice
Responsible for retrieving the list of containers from the upstream server
Used together with the XtceTmProcessor to find out which containers a specific data packet is representing
A parameter value corresponding to a parameter that has been extracted from a container.
Keeps track of where we are when processing a packet.
 
the container result is built during a container processing
Interface implemented by all the classes that can provide containers to a ContainerListener
Keeps track of the subscribers to the containers of a processor.
 
 
This sits in front of the ContainerRequestManager and implements subscriptions based on NamedObjectId taking care to send to the consumers the containers with the requested id.
Request context used in RPC-style endpoints.
 
 
 
 
Sends events and websocket messages for FOP1 state changes and alerts
Assembles TC packets into TC frames as per CCSDS 232.0-B-3 and sends them out via FOP1
 
Exception indicating a frame is corrupted
Used by AlarmServer to indicate when the acknowledge on an alarm did not work.
 
CrashHandler is used to handle extreme problems that need to reach operator (or sysadmin) attention.
 
 
Cylcic Redundancy Check (CRC-CCIIT 0xFFFF) with the polynomial:
 
 
 
 
 
 
 
 
 
Link postprocessor for CSP 1.x commands (CubeSat Protocol)
Helper class for accessing CubeSat Space Protocol v1 fields
Link preprocessor for CSP 1.x packets (CubeSat Protocol)
Parses a directory listing from Comma Separated Values (CSV) formatted data.
Decoder for CCSDS Unsegmented time Code as specified in TIME CODE FORMATS, CCSDS 301.0-B-4, Nov 2010 The time code is composed by P-Field (preamble field) 8 or 16 bits optional T-Field - up to 7+10 bytes (although it could be longer for custom codes)
 
used to signal inconsistencies found in the database
 
Interface to be implemented by the custom XTCE DataEncoding decoders - fromBinaryTransformAlgorithm TODO: unify somehow with the algorithms in order to allow for example to use input parameters (i.e. value of other parameters may be needed in the decoding) Until then, please use the AbstractDataDecoder interface to not need to implement any of the AlgorithmExecutor
 
Interface to be implemented by the custom XTCE DataEncoding decoders - toBinaryTransformAlgorithm
 
Decodes TM data according to the specification of the DataEncoding This is a generic catch all decoder, relies on specific custom decoders implementing the DataDecoder interface when necessary.
Encodes TC data according to the DataEncoding definition
creates raw values according to the data encoding used
 
Like the Meter but gives the data rates at 5 seconds mean rates
Types supported by yarch.
 
 
 
Protobuf type Event
Protobuf type Event
 
this message has been copied in Yamcs 5 from pvalue.proto and is used when storing parameter values in tables (ParameterValueColumnSerializer.java).
this message has been copied in Yamcs 5 from pvalue.proto and is used when storing parameter values in tables (ParameterValueColumnSerializer.java).
 
Protobuf enum ProtoDataType
Iterator that does not support seek.
 
 
 
Execute a statement:
Annotation used to mark service that have been deprecated.
Wrapper around RocksDb iterator that iterates all the keys with a prefix in descending order
Wrapper around a rocksdb iterator that only supports prev() and is restricted to a range.
 
Stores user, group and application information in the Yamcs database.
Identifies users and service accounts based on authentication information stored in the Yamcs Directory.
Stores users and groups in the Yamcs DB.
 
 
 
Generates parameters containing information about the disk IO, similarly with what the command iostat provides.
expandable double array
 
 
Stores configuration related to Master channels for downlink.
 
Transfer frame is an interface covering the three CCSDS transfer frames types: TM (CCSDS 132.0-B-2) AOS (CCSDS 732.0-B-3) UNIFIED ( 732.1-B-1)
One-pass downsampler for time-series data (i.e. numeric archived parameters), where the number of recorded data points are not known upfront.
A cumulative sample that keeps track of a rolling average among others.
 
Database "loader" that simply creates an empty SpaceSystem with the given name
 
An enumerated value is a value that has both an integer and a string representation.
 
Computes the checksum inside the CCSDS packet
 
Escapes HTML in a string.
Handles alarms for events.
Receives event alarms from the AlarmServer and sends them to the events_alarms stream to be recorded
Crash handler that reports events via an event producer Created by msc on 28/11/16.
 
 
The id of an event alarm is its (source,type)
Library of functions available from within Algorithm scripts using this naming scheme:
 
 
Sets up the archiving of the events coming on events_realtime and events_dump streams into the yarch table events.
 
 
 
Keeps track of attributes associated with an execution context of a query: tablespace, database and snapshots
Marks a class or method as experimental.
 
 
Protobuf type ExternalIdentity
Protobuf type ExternalIdentity
 
 
This class is similar to FastPFOR but uses a small block size.
Because the FastPFOR codec uses quite some memory, we use this factory to limit the number of created objects to one per thread
Handles favicon requests.
 
 
 
 
A file-based configuration resolver.
Structure is
 
 
Only mapping a transaction ID to a download bucket at the moment
Interface for retrieving and saving the list of files of a certain remote directory.
 
TM packet data link which reads telemetry files from a specified directory.
A Put.request is a primitive that requests data delivery from a source to a destination
 
Generates parameters containing information about the system disks: total space, available space and percentage used.
NOT IMPLEMENTED
 
BucketDatabase implementation that maps objects to files on a file system.
 
 
 
The file transfer service defines an interface for implementing file transfers.
 
 
 
 
 
Token literal values and constants.
Token Manager.
 
 
 
This input stream reads packets of a configurable fixed packet size.
Decodes time on a fixed number of bytes.
Decodes milliseconds from fractional seconds stored in a 64-bit float
float array
Implements the floating point compression scheme described here: http://www.vldb.org/pvldb/vol8/p1816-teller.pdf
 
 
 
When there was an authz exception
 
Saves frames into streams.
 
 
 
Generic packet reader that splits the stream into packets based on the length of the packet
Generic packet preprocessor.
 
A filter that discards log messages that are specific to a Yamcs instance.
Finds a list of files according to a glob pattern.
Maps archived tuples to GPB
Helper methods for dealing with Protobuf "well-known types".
Auxiliary class for GPS CCSDS time.
A group is way to manage a set of users.
Protobuf type GroupCollection
Protobuf type GroupCollection
 
Protobuf type GroupRecord
Protobuf type GroupRecord
 
 
 
 
Decoder that returns the string value in hex format of read bytes.
information about histogram.
Iterator over histogram records The iterator offers a partial ordering - for one column the records are sorted by time
Sends histogram data to a stream.
rebuilds the histogram for a table
Stores a record in the histogram database.
 
 
Writes histograms for one table.
 
Default HTTP exception.
 
Handles handshakes and messages.
Server-wide HTTP server based on Netty that provides a number of Yamcs web services: REST API WebSocket API Static file serving
 
 
 
Converts HTTP requests to Protobuf messages used in API definitions.
 
 
Handles idle frames by ignoring them.
 
 
 
List which is indexed by a key in addition to its natural integer index
 
 
 
Request index (histogram) information about tm packets, pp groups and commands
 
Performs histogram and completeness index retrievals.
 
 
 
 
 
Produces tuples as result of:
 
 
 
Yamcs high resolution instant storing milliseconds since 1970-01-01T00:00:00 TAI (including leap seconds) and picoseconds.
expandable array of ints
Interface describing a standard CODEC to compress integers.
Something really wrong and unexpected occurred on the server.
Stream created by the "create stream statement"
 
32 bit integers encoded as deltas of deltas (good if the values are relatively constant or in increasing order)
Essentially a mutable wrapper around an integer.
The output of the algorithm does not match the parameter it is supposed to be assigned to
 
 
 
 
Exception thrown by services when receiving an invalid request usually via the http api, case in which it transformed into HTTP Bad Request
 
An AuthModule that enforces a login of one fixed user account, where the remote IP address must match one of the configured IP address rules.
 
 
ISO CRC calculator as described in ECSS-E-ST-70-41C 15 April 2016, appendix B.2
 
This implements CCSDS packets as used in ISS (International Space Station).
 
 
 
 
Wrapper around the (weird) JAAS configuration API.
 
 
Generates executors for java-expression algorithms.
 
A minimalistic formatter that is intended for use with systems that use the systemd journal.
 
 
 
Identifies a user that was authenticated via a JWT bearer token
 
Does password-based login against a Kerberos host.
Cache for the last known value of each parameter.
 
 
 
 
 
 
 
 
 
 
Thrown by a method that causes a user/system specified limit to be exceeded.
A source of data into yamcs; Currently TM, TC and Parameter
 
 
 
Used by LinkManager to distribute data link related updates
Service that manages all the data links: is endpoint for the /links API calls for the commanding links it will only send commands if the link is enabled.
Object that is used to persist link state information across Yamcs restarts.
 
 
Implements local parameters - these are parameters that can be set from the clients.
 
default crash handler that just print a message in the log
 
long array
 
 
 
Provides common functionality to assemble and disassemble GPB messages
Used by ManagementService to distribute various types of management-related updates
Responsible for providing to interested listeners info related to creation/removal/update of: instances and processors - see ManagementListener streams and tables - see TableStreamListener command queues - see CommandQueueListener
Exception class carrying the failure reason (text provided by the user) of why a manual activity completed exceptionally.
Handles incoming TM frames by distributing them to different VirtualChannelHandlers
Multiplexes TC frames from Virtual Channels based on priority schemes.
runs on the master side sending data to slave
 
 
 
Verifies commands by checking MatchCriteria.
Executes XTCE math algorithms MathAlgorithm All the input parameters are converted to doubles and there is one single double output parameter
 
Interface used by the algorithms to evaluate math operations.
Provides some of the operations that are required for XTCE MathOperation but are not part of standard java Math.
Wraps an XtceDb object.
 
 
 
 
 
MdbPageBuilder<T extends org.yamcs.xtce.NameDescription>
Builds a page result for a collection of matching space systems and other items.
MdbPageBuilder.MdbPage<T extends org.yamcs.xtce.NameDescription>
 
 
Syntactic sugar around a media type string.
General purpose facility for persisting state information.
 
 
Defines all the message types that are exchanged between master and slave.
 
 
 
 
 
 
When an unsupported HTTP method was used for a specific path
Some Mil1750A encoding/decoding functions.
Maps files to Internet media types based on their file extension.
saves events into a queue (to be used by unit tests)
Retrieves multiple parameters from the Parameter Archive.
A collection of ParameterValueSegment with a common timeSegment.
 
 
Same as SegmentIterator but provides segments for multiple parameters from the same group in one step.
 
 
 
Matches a search term with an XTCE name or any of the aliases
Stateless continuation token for paged MDB requests.
 
 
 
 
 
 
When a resource (only the part identified by the request uri) could not be found.
 
 
This represents a NULL value coming from some sql expression for example: select null from x
An object privilege is the right to perform a particular action on an object.
Type qualifier for grouping object privileges.
Segment for all non primitive types.
 
 
 
 
Identifies a user at the Open ID Provider.
Identifies a user at the Open ID Provider.
An Authentication Request is an OAuth 2.0 Authorization Request that requests that the End-User be authenticated by the Authorization Server.
AuthModule that identifies users against an external identity provider compliant with OpenID Connect (OIDC).
 
 
 
 
 
 
 
 
 
Receives data chunk by chunk and assembles it into packets.
Interface implemented by the classes that read packets from an input stream.
The packet preprocessor is responsible for extracting basic information required for yamcs packet processing: packet generation time packet acquisition time sequence count
It is assumed that the (generation time, sequence count) uniquely identify the packet.
 
Exception thrown when a packet is longer than a defined limit
 
Part of the TM processing chain.
 
 
The parameter archive stores data in partitions(optional) -> intervals -> segments.
 
 
 
 
 
Used by the ParameterRequestManager to cache last values of parameters.
Used by the ParameterRequestManager to deliver parameters
Interface for components providing parameters aquired from external systems.
Formats in tab separated format parameters.
 
Stores a map between List<parameter_id> and ParameterGroup_id.
 
The parameter archive gives each (fqn, rawType, engType) a numeric 32 bits pid.
Stores a map (parameter_fqn, type) -> parameter_id
A list of parametersIds with values all having the same timestamp
 
Iterator over values of one (parameterId, group id)
 
 
 
 
Archives and retrieves the value of parameters that have the persistence flag activated.
This is the interface implemented by the ParameterRequestManager to receive parameters from the different parameter providers.
Makes the connection between ParameterProvider and ParameterProcessor
interface implemented by all the classes that can provide parameters to the ParameterProcessorManager
builds ranges of parameters
 
 
 
ParameterRecorder Records (processed) Parameters
Replays parameters from tables recorded by the ParameterRecorder
Expected class type for use with ReplayFactory Adds functionality for stopping a replay, and has support for pagination
Contains retrieval options used when extracting parameters from the parameter archive.
Distributes parameters from ParameterProcessorManager to ParameterConsumer
Used by the ParameterDataLink to propagate processed parameters inside Yamcs.
 
 
 
 
Responsible for converting between raw and engineering value by usage of calibrators or by simple type conversions.
Contains various static methods to help work with XTCE ParameterType
 
an array of values for one ParameterId
 
Stores a collection of ParameterValue indexed on Parameter
 
Stores parameter values for one parameter over a time range.
groups together a parameter value with a telemetry item id.
Holder class for a parameter together with the id what used to subscribe (or request) it.
 
This sits in front of the ParameterRequestManager and implements subscriptions based on NamedObjectId taking care to send to the consumers the parameters with the requested id.
RocksDb style iterator.
This exception is thrown when parse errors are encountered.
This exception is thrown when parse errors are encountered.
Holds values related to members of aggregates or arrays
Holds values related to members of aggregates or arrays
stores information about Partition of a table It is subclassed by storage engines to store additional information
A list of sorted, non overlapping TimeInterval
 
 
Iterates over time based intervals of a partition
Keeps track of partitions and histograms for one table.
For tables partitioned by time this holds all the partitions for a given time interval.
Generates password hashes for use in users.yaml
 
A Pause.request is a primitive that requests a certain transaction to be paused*
 
 
An interface for an iterator that allows peeking at the current value.
A simple timer that can be inserted in the code to measure the performance of certain operations.
Parameter Group segment - keeps references to Time and Value segments for a given parameter group and segment.
 
Indicates a failure coming from a Plugin.
Controls the loading of Yamcs plugins.
 
A calibration type where a curve in a raw vs calibrated plane is described using a set of polynomial coefficients.
Stores command information
 
This class holds live information used during a (XTCE) processing.
 
This class helps keeping track of the different objects used in a Yamcs Processor - i.e. all the objects required to have a TM/TC processing chain (either realtime or playback).
Configuration options for a processor
Used in yamcs.instance.yaml to create processors at yamcs startup
Holds information related and required for XTCE processing.
 
Used to create processors as defined in processor.yaml
 
This interface has to be implemented by all services that run as part of a processor.
 
Global service that launches and supervises a configured program or script.
A database that allows to store and retrieve protobuf messages.
 
 
CRC-32 error detection code as specified in CCSDS 211.0-B-5 PROXIMITY-1 SPACE LINK PROTOCOL— DATA LINK LAYER
 
 
 
 
 
Implementation for ECSS PUS (ECSS-E-ST-70-41C) packets.
Put.request (destination CFDP entity ID, [source file name], [destination file name], [segmentation control], [fault handler overrides], [flow label], [transmission mode], [closure requested], [messages to user], [filestore requests])
 
Helper class to programmatically build SQL queries.
 
 
 
 
Event producer that swallows the events
CCSDS randomizer as per CCSDS 131.0-B-3(TM) and CCSDS 231.0-B-3 (TC)
Abstract class storing a raw value, engineering value and a generation time.
Decodes raw frames performing derandomization and error correction.
 
 
Stores users objects in rocksdb
reads the rdbConfig from the yamcs.yaml and provides RocksDB Options when creating and opening databases singleton
 
manufacturer of RDB databases residing under a sub-directory which is normally the Tablespace.getDataDir().
 
 
 
Handles partitions for one table.
 
sequence stored in the Rocksdb metadata.
Storage Engine based on RocksDB.
Holds together the RDB properties related to one table.
 
table writer for the rocksdb2 engine.
Listener that is called when Yamcs has fully started.
Realtime archive filler task - it works even if the data is not perfectly sorted
Simple model from TimeService implementing the mission time as the wallclock time
Reed-Solomon encoder/decoder.
 
Expressions of type x > y or x=y
 
A decoder that returns a binary value containing all of the remaining bytes.
 
AuthModule that identifies users based on an HTTP header property.
Abstracts some common logic for creating replays
 
 
 
Yarch replay server A note about terminology: we call this replay because it provides capability to speed control/pause/resume.
Provides telemetry packets and processed parameters from the yamcs archive.
 
Replication TCP client - works both on the master and on the slave side depending on the config
Stores transactions in a memory mapped file.
Implements the master part of the replication.
 
 
TCP replication server - works both on the master and on the slave side depending on the channel handler
 
 
sent from Slave to Master directly when the Master is the TCP server or after a Wakeup when the Slave is the TCP server
sent from Slave to Master directly when the Master is the TCP server or after a Wakeup when the Slave is the TCP server
Protobuf enum Request.Type
 
 
 
 
Protobuf type Response
Protobuf type Response
 
 
A Resume.request is a primitive that requests a certain paused transaction to be resumed*
 
A custom data decoder that returns a binary value that has all the bytes reversed from the encoded binary.
A custom data encoder that converts provided binary to encoded binary in the reverse byte order.
Handles robots.txt requests, to advise against web crawling.
 
Command line utility for doing rocksdb operations
Makes system parameters under /yamcs/<instance-id>/rocksdb/
Collection of system and object privileges.
 
 
 
This is like a tuple used in the context of table writing to collect values used for histograms and secondary indices.
 
 
 
Represents the execution context of one algorithm.
Handles the creation of algorithm executors for script algorithms for a given language and scriptEngine (currently javascript or python are supported).
 
 
Helper utility for sending systemd notification events about state changes.
iterates through a table based on the secondary index range.
Writes secondary index for one table.
 
Responsible for Identity and Access Management (IAM).
 
For a given simple parameter id and group id, iterates over all segments in the parameter archive (across all partitions).
Holder, encoder and decoder for the segment keys (in the sense of key,value storage used for RocksDb)
The SegmentRequest is part of a NAK PDU to indicate a missing part of a file.
Corresponds to a queries like "select 2*x, x+sum(y+3) from t[...] where x>5 group by x" chain of data/processing (D=Data, P=Processing, agg=aggregate):
 
 
 
 
 
Sequences generate incrementing numbers and are persisted to the database (i.e. upon restart they continue from where they left)
 
 
 
 
A message observer that implements a streaming response over HTTP using chunked transfer encoding.
Represents an non-human service or application registered with Yamcs.
Protobuf type ServiceAccountRecordDetail
Protobuf type ServiceAccountRecordDetail
 
 
Something really wrong and unexpected occurred on the server.
 
Holder for a service together with its name and config.
 
 
Implementation-agnostic session store.
 
 
 
 
 
 
 
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
For a given parameter id and group id, iterates over all parameters in the parameter archive (across all segments and partitions).
Estimates an ordinary least squares regression model with one independent variable.
common implementation for statements which do not return a stream of results but just a limited set
Simulation time model.
Histogram writer for the tables having one column histogram (which is actually all standard tables from Yamcs)
Retrieves values for a single parameter from the parameter archive.
Retrieves values for one parameter combining parameter archive (for past data) and cache (for recent data).
An AuthModule that enforces a login of one fixed user account
 
 
Interface describing a standard CODEC to compress integers.
Prints all events via java logging.
Handles parameters that can be set from the clients.
sorted int array
TimeSegment stores timestamps relative to the interval start.
Interface implemented by the database loaders.
This is the analogous to the SpaceSystemLoader and is used for writing Mdb information to files (or to other media such as databases)
Specifies the valid structure of a YConfiguration instance.
A specialized Spec that also has a name.
 
 
Extra information to be attached to any generated ValidationException
 
 
 
A calibration type where a segmented line in a raw vs calibrated plane is described using a set of points.
Implements SPNEGO authentication against an external Kerberos host.
Keeps track of current whereabouts of the spreadsheet loader.
Wrapper around v6 or v7 xls loader.
Groups all exceptions generated by the spreadsheet loader.
 
 
 
Keep track of the lifecycle of a stacked command.
 
 
 
 
Streams are means to transport tuples.
 
 
provides command history from streams
Injects the command history updates in the command history stream
Stores the value of the streamConfiguration parameter from yamcs.instance.yaml Used to create the streams at Yamcs startup and by various other services (recording, processor, ...)
 
 
Event producer used from inside Yamcs to report events.
 
Protobuf type StreamInfo
Protobuf type StreamInfo
 
 
Run at the very beginning of Yamcs startup; creates different streams required for Yamcs operation There are a number of "hardcoded" stream types that can be created without specifying the schema (because the schema has to match the definition expected by other services).
Provides parameters from yarch streams (pp_realtime) to ParameterProcessorManager
Sends collection of parameters to stream by
 
Exception thrown for errors in sql queries.
 
 
Token literal values and constants.
Token Manager.
 
StreamSqlResult which stores a list of results
Tag interface for all StreamSQL statements.
 
Sends commands to yamcs streams
A matcher is associated to a stream and used to match commands that are sent to that stream
Receives packets from yamcs streams and sends them to the Processor/TmProcessor for extraction of parameters.
 
 
 
 
 
 
keeps track of the parameters and containers subscribed (because we only want to extract those)
set of subscription ids - represented as sorted array no duplicate allowed copy on write
 
 
JUL appender that emits to syslogd over UDP with messages formatted according to RFC 3164 (BSD syslog).
Deprecated.
Interface implemented by classes that want to provide system parameters.
Collects each second system processed parameters from whomever registers and sends them on the sys_var stream
A system privilege is the right to perform a particular action or to perform an action on any object of a particular type.
Special AuthenticationInfo that can be used by AuthModules to identify some access as the System user.
 
 
Stores properties for table columns
A table definition consists of a (key,value) pair of tuple definitions.
Constructs TableDefinition from .def yaml files.
Implements skeleton for table streamer that uses PartitionManager to handle partitioning.
 
Tablespaces are used to store data by the RdbStorageEngine.
associated to each bucket
associated to each bucket
 
associated to each user object
associated to each user object
 
Protobuf type PartitioningInfo
Protobuf type PartitioningInfo
Protobuf enum PartitioningInfo.PartitioningType
 
Protobuf type ProtoTableDefinition
Protobuf type ProtoTableDefinition
 
to allow future extensions we define multi-column secondary indices for each table as of now only a single index on one column is supported
to allow future extensions we define multi-column secondary indices for each table as of now only a single index on one column is supported
 
Protobuf type TableColumnInfo
Protobuf type TableColumnInfo
Protobuf type TableColumnInfo.EnumValue
Protobuf type TableColumnInfo.EnumValue
 
 
This is used to encode values in the tablespace metadata database
This is used to encode values in the tablespace metadata database
Protobuf enum TablespaceRecord.Type
 
Protobuf type TimeBasedPartition
Protobuf type TimeBasedPartition
 
Implement and subscribe to the ManagementService to know when new tables or streams are created/removed
Helper for outputting records in columnar fashion without harcoding column widths
 
 
 
Walks over one yarch table providing operations for select, udpdate, delete
 
 
 
Utility class to convert between TAI and UTC.
 
 
Interface implemented by components that send commands to the outer universe
 
Configuration (managed parameters) used for generation of TC frames as per CCSDS 232.0-B-3
 
Configuration for one Virtual Channel
Assembles command packets into TC frames as per CCSDS 232.0-B-4.
Keeps track of where we are when filling in the bits and bytes of a command
 
Sends raw command packets on TCP socket.
 
 
Generic exception to throw for problems encountered during TC or TM processing
TC Transfer Frame as per
 
 
 
Token literal values and constants.
Token Manager.
Processes a template source.
 
Represents a token (or 'authorization_code' in oauth terms) issued by an external identity server.
 
 
Can be used in BinaryParameterEncoding to decode binary data directly to absolute times
 
On-board time correlation service (inspired from SCOS2K (ESA MCS)).
Interface for time decoders used in the PacketPreprocessor
 
This class provides times in terms of milliseconds since 1970TAI
Time interval where both ends can be open.
Filters an input iterator to the intervals that match the given timeInterval
 
 
 
 
Used for displaying day/night, TDRS, GS visibility, milestones (e.g. launch, a deadline), general items covering large time intervals for which no specific action is taken (e.g. mission phase).
A timeline item is the entity that appears in the timeline bars.
 
 
 
This service manages the Yamcs timeline.
 
 
sent regularely from Master to Slave contains the mission time relation to the local time used also as a heartbeat to keep the TCP link alive and detect link failures
sent regularely from Master to Slave contains the mission time relation to the local time used also as a heartbeat to keep the TCP link alive and detect link failures
 
Time of flight estimator.
Used for polynomial interpolation of time of flight based on ERT.
 
Implements different schemes for partitioning by time.
Implements a timer used by CFDP for verifying the sending of EOF, FIN and NAK PDUs
The time service provides the so call mission time.
Stateless continuation token for paged requests that output timesorted data
 
Picosecond resolution timestamp stored as (millis, picos)
Type, Length, Value
Decodes frames as per CCSDS 132.0-B-3
 
Interface for (completeness) TmIndex.
 
Packet with acquisition time, generation time and sequence count.
Interface for components reading packets from external parties.
 
 
Used by the TmPacketDataLink to propagate packets inside Yamcs.
 
Describes the input token stream.
Describes the input token stream.
Token Manager Error.
Token Manager Error.
Token Manager Error.
Token Manager Error.
Store capable of generating a chain of refresh tokens.
 
Context for a specific RPC call over a (shared) WebSocket connection.
 
Decodes raw frame data into a transfer frame of one of three CCSDS types AOS, TM or USLP
 
 
 
Contains the tuple value (as an array of Columns) together with a pointer to its definition
 
 
A source of tuples.
Receives PP data via UDP.
Sends raw packets on UDP socket.
Sends TC as TC frames (CCSDS 232.0-B-3) or TC frames embedded in CLTU (CCSDS 231.0-B-3).
A UDP-based link that acts as a client: sending TC and receiving TM on the same socket pair.
 
Receives telemetry packets via UDP.
Receives telemetry fames via UDP.
 
 
 
When the request was valid, but did not pass authentication.
Allows wrapping any checked exception without overloading signatures.
 
 
 
 
 
 
 
Stores configuration related to Master channels for uplink.
 
 
A user contains identifying information and a convenient set of methods to perform access control.
Protobuf type UserAccountRecordDetail
Protobuf type UserAccountRecordDetail
 
 
A password-based token, usually associated with BASIC AUTH requests (convenient through curl)
Generates password hashes for use in users.yaml
 
Covers a user session.
Decodes frames as per CCSDS 732.1-B-1
 
Transfer Frames as per: CCSDS RECOMMENDED STANDARD FOR UNIFIED SPACE DATA LINK PROTOCOL CCSDS 732.1-B-1 October 2018
Routine utility functions.
 
 
This class loads database from excel spreadsheets.
static fields and methods to reduce the size of the SpreadsheetLoader
This class loads database from excel spreadsheets.
static fields and methods to reduce the size of the SpreadsheetLoader
This exception indicates that an error has occurred while performing a validate operation.
 
Union like class
Stores parameters of the same type as array For primitive types, it uses much less memory than having an Value[]
A ParameterValue as passed to an algorithm.
Command verifier which succeeds when a parameter changes with a delta above a threshold.
 
 
This represents a constant value coming from some sql expression for example: select 3 from x
 
Interface for segments of columnar data.
 
 
 
 
decodes an array of varints
 
 
Called from the MasterChannelFrameHandler to handle TM frames for a specific virtual channel.
Stores configuration related to Virtual Channels
Handles packets from one VC
Handlers uplink data in a virtual channel
Stores configuration related to Virtual Channels for uplink
Class that can be used to capture the outcome of a verifier execution.
Library of functions available from within Algorithm scripts using this naming scheme:
 
sent from Master to Slave when the Slave is the TCP server the Slave will send back a Request on the same socket
sent from Master to Slave when the Slave is the TCP server the Slave will send back a Request on the same socket
 
File handler that watches the file it is logging to.
Receives (potentially compressed) websocket frames (each containing a message), and handles message priorities, to drop low priority messages, if they would otherwise exceed the high write watermark.
 
 
 
 
Encodes ServerMessage to either BinaryWebSocketFrame or TextWebSocketFrame depending if the protobuf or json has to be sent.
RFC 8615 endpoint used by various protocols.
 
 
 
Experimental export of Mission Database to XTCE.
Deprecated.
XTCE XML loader.
Writes MDB to files in XTCE format.
Generic RuntimeException to be used when encountering an unexpected problem in the XTCE processing
Extracts parameters out of packets based on the XTCE description
Does the job of getting containers and transforming them into parameters which are then sent to the parameter request manager for the distribution to the requesters.
Records XTCE TM sequence containers.
Provides replay of the telemetry recorded by XtceTmRecorder
 
 
 
Command line utility for doing yamcs stuff.
 
 
Yamcs TM link - subscribes to realtime telemetry
Base class for all checked Yamcs exceptions (some day)
Inspired from Guava services, this class offers the following states: OFFLINE INITIALIZING INITIALIZED STARTING RUNNING STOPPING FAILED transitions are allowed back to OFFLINE from all steady states
 
Customized version of LogManager so that we can keep logging from within shutdown hooks.
 
Yamcs Parameter link - receives parameters from a Yamcs upstream server.
Yamcs server together with the global instances
Represents a Yamcs instance together with the instance specific services and the processors
 
 
Required interface of a Yamcs Service.
 
Yamcs TM Archive link - fetches archive data
Yamcs TM link - subscribes to realtime telemetry
Provides access to build-time information of the Yamcs project.
 
Handles all tables/streams/indexes for a Yamcs server
Handles tables and streams for one Yamcs Instance
 
Performs a replay from Yarch So far supported are: TM packets, PP groups, Events, Parameters and Command History.
A configuration object is a wrapper around a Map&ltString, Object&gt which keeps track to a parent and its original file (if any).
Introduced to be able to detect when a configuration file was not specified (as opposed to when there's a validation error inside).
Default config file resolver.
Default property provider.
 
 
 
wrapper around RocksDB that keeps track of column families.