libcaf  0.17.1
 All Classes Namespaces Functions Variables Typedefs Enumerations Enumerator Friends Groups Pages
Class Hierarchy
This inheritance list is sorted roughly, but not completely, alphabetically:
[detail level 12345]
oCcaf::byte_address< ipv4_address >
oCcaf::byte_address< ipv6_address >
oCcaf::abstract_channelInterface for all message receivers
oCcaf::abstract_composable_behaviorMarker type that allows CAF to spawn actors from composable states
oCcaf::actorIdentifies an untyped actor
oCcaf::actor_addrStores the address of typed as well as untyped actors
oCcaf::actor_clockA monotonic clock for scheduling timeouts and delayed messages
oCcaf::actor_companionAn co-existing actor forwarding all messages through a user-defined callback to another object, thus serving as gateway to allow any object to interact with other actors
oCcaf::actor_configStores spawn-time flags and groups
oCcaf::actor_control_blockActors are always allocated with a control block that stores its identity as well as strong and weak reference counts to it
oCcaf::actor_ostreamProvides support for thread-safe output operations on character streams
oCcaf::actor_registryA registry is used to associate actors to IDs or atoms (names)
oCcaf::actor_systemActor environment including scheduler, registry, and optional components such as a middleman
oCcaf::actor_system::moduleAn (optional) component of the actor system
oCcaf::actor_system_configConfigures an actor_system on startup
oCcaf::allowed_unsafe_message_type< T >Template specializations can whitelist individual types for unsafe message passing operations
oCcaf::atom_constant< V >Lifts an atom_value to a compile-time constant
oCcaf::attachableCallback utility class
oCcaf::attachable::tokenRepresents a pointer to a value with its subtype as type ID number
oCcaf::behaviorDescribes the behavior of an actor, i.e., provides a message handler and an optional timeout
oCcaf::blocking_actorA thread-mapped or context-switching actor using a blocking receive rather than a behavior-stack based message processing
oCcaf::blocking_actor::do_receive_helperImplementation helper for blocking_actor::do_receive
oCcaf::blocking_actor::mailbox_policyConfigures the FIFO inbox with two nested queues:
oCcaf::blocking_actor::receive_condRepresents pre- and postconditions for receive loops
oCcaf::blocking_actor::receive_for_helper< T >Implementation helper for blocking_actor::receive_for
oCcaf::blocking_actor::receive_while_helperImplementation helper for blocking_actor::receive_while
oCcaf::byte_address< Derived >Base type for addresses based on a byte representation such as IP or Ethernet addresses
oCcaf::callback< Ts >Describes a simple callback, usually implemented via lambda expression
oCcaf::composable_behavior< TypedActor >Base type for composable actor states
oCcaf::composable_behavior_base< MPI >Generates an interface class that provides operator()
oCcaf::composed_type< Xs, Ys, Zs, Rs >Computes the type for f*g (actor composition)
oCcaf::config_optionDefines a configuration option for the application
oCcaf::config_option::meta_stateCustom vtable-like struct for delegating to type-specific functions and storing type-specific information shared by several config options
oCcaf::config_option_adderAdds config options of the same category to a config_option_set
oCcaf::config_option_setA set of config_option objects that parses CLI arguments into a settings object
oCcaf::config_valueA type for config parameters with similar interface to a variant
oCcaf::config_value_access< T >
oCcaf::config_value_access< dictionary< V > >Implements automagic unboxing of dictionary<V> from a homogeneous config_value::dictionary
oCcaf::config_value_access< std::tuple< Ts...> >Implements automagic unboxing of std::tuple<Ts...> from a heterogeneous config_value::list
oCcaf::config_value_access< std::vector< T > >Implements automagic unboxing of std::vector<T> from a homogeneous config_value::list
oCcaf::cow_tuple< Ts >A copy-on-write tuple implementation
oCcaf::data_processor< Derived >A data processor translates an object into a format that can be stored or vice versa
oCcaf::default_downstream_manager< F >Selects a downstream manager implementation based on the signature of various handlers
oCcaf::default_sum_type_access< T >Allows specializing the sum_type_access trait for any type that simply wraps a variant and exposes it with a get_data() member function
oCcaf::delegated< Ts >Helper class to indicate that a request has been forwarded
oCcaf::dictionary< V >Maps strings to values of type V, but unlike std::map<std::string, V> accepts string_view for looking up keys efficiently
oCcaf::down_msgSent to all actors monitoring an actor when it is terminated
oCcaf::downstream< T >Grants access to an output stream buffer
oCcaf::downstream_managerManages downstream communication for a stream_manager
oCcaf::downstream_manager::path_predicatePredicate object for paths
oCcaf::downstream_manager::path_visitorFunction object for iterating over all paths
oCcaf::downstream_msgStream messages that travel downstream, i.e., batches and close messages
oCcaf::downstream_msg::batchTransmits stream data
oCcaf::downstream_msg::closeOrderly shuts down a stream after receiving an ACK for the last batch
oCcaf::downstream_msg::forced_closePropagates a fatal error from sources to sinks
oCcaf::durationTime duration consisting of a time_unit and a 64 bit unsigned integer
oCcaf::errorA serializable type for storing error codes with category and optional, human-readable context information
oCcaf::execution_unitIdentifies an execution unit, e.g., a worker thread of the scheduler
oCcaf::exit_msgSent to all links when an actor is terminated
oCcaf::expected< T >Represents the result of a computation which can either complete successfully with an instance of type T or fail with an error
oCcaf::expected< void >The pattern expected<void> shall be used for functions that may generate an error but would otherwise return bool
oCcaf::extend< Base, Derived >Allows convenient definition of types using mixins
oCcaf::function_view< Actor >A function view for an actor hides any messaging from the caller
oCcaf::fused_downstream_manager< T, Ts >::non_owning_ptrState held for each slot
oCcaf::group_down_msgSent to all members of a group when it goes offline
oCcaf::group_moduleInterface for user-defined multicast implementations
oCcaf::handle< Subtype, InvalidType, InvalidId >Base class for IO handles such as accept_handle or connection_handle
oCcaf::has_make_error< T >Evaluates to true if T is an enum with a free function make_error for converting it to an error
oCcaf::has_sum_type_access< T >Evaluates to true if T specializes sum_type_access
oCcaf::illegal_message_elementMarker class identifying classes in CAF that are not allowed to be used as message element
oCcaf::inbound_pathState for a path to an upstream actor (source)
oCcaf::inbound_path::stats_tStores statistics for measuring complexity of incoming batches
oCcaf::inbound_path::stats_t::calculation_resultWraps the resulf of stats_t::calculate()
oCcaf::inbound_path::stats_t::measurementWraps a time measurement for a single processed batch
oCcaf::inbound_stream_slot< In >Wraps a stream slot ID for inbound paths with the full type information of the path creation
oCcaf::index_mappingMarker for representing placeholders at runtime
oCcaf::infer_handle_from_class< T, bool >Deduces actor for dynamically typed actors, otherwise typed_actor<...> is deduced
oCcaf::infer_handle_from_fun< F, Trait >Deduces an actor handle type from a function or function object
oCcaf::infinite_tRepresents an infinite amount of timeout for specifying "invalid" timeouts
oCcaf::intrusive_cow_ptr< class >An intrusive, reference counting smart pointer implementation with copy-on-write optimization
oCcaf::intrusive_ptr< class >An intrusive, reference counting smart pointer implementation
oCcaf::io::acceptor_closed_msgSignalizes that a broker acceptor has been closed
oCcaf::io::acceptor_passivated_msgSignalizes that an acceptor has entered passive mode
oCcaf::io::broker_servant< Base, Handle, SysMsgType >Base class for scribe and doorman
oCcaf::io::connection_closed_msgSignalizes that a broker connection has been closed
oCcaf::io::connection_passivated_msgSignalizes that a connection has entered passive mode
oCcaf::io::data_transferred_msgSignalizes that a certain amount of bytes has been written
oCcaf::io::datagram_sent_msgSignalizes that a datagram with a certain size has been sent
oCcaf::io::datagram_servant_closed_msgSignalizes that a datagram endpoint has entered passive mode
oCcaf::io::datagram_servant_passivated_msgSignalizes that a datagram sink has entered passive mode
oCcaf::io::network::datagram_handler_impl< ProtocolPolicy >A concrete datagram_handler with a technology-dependent policy
oCcaf::io::network::event_handlerA socket I/O event handler
oCcaf::io::network::event_handler::stateStores various status flags and user-defined config parameters
oCcaf::io::network::interfacesUtility class bundling access to network interface names and addresses
oCcaf::io::network::ip_endpointA hashable wrapper for a sockaddr storage
oCcaf::io::network::multiplexer::supervisorMakes sure the multipler does not exit its event loop until the destructor of supervisor has been called
oCcaf::io::network::protocolBundles protocol information for network and transport layer communication
oCcaf::io::network::receive_bufferA container that does not call constructors and destructors for its values
oCcaf::io::new_connection_msgSignalizes a newly accepted connection from a broker
oCcaf::io::new_data_msgSignalizes newly arrived data for a broker
oCcaf::io::new_datagram_msgSignalizes that a datagram with a certain size has been sent
oCcaf::ipv4_endpointAn IP endpoint that contains an ::ipv4_address and a port
oCcaf::ipv6_endpointAn IP endpoint that contains an ::ipv6_address and a port
oCcaf::is_actor_handle< T >Checks whether T is an actor or a typed_actor<...>
oCcaf::is_typed_actor< T >Evaluates to true if T is a typed_actor<...>
oCcaf::logger::configCombines various logging-related flags and parameters into a bitfield
oCcaf::logger::eventEncapsulates a single logging event
oCcaf::logger::fieldRepresents a single format string field
oCcaf::logger::line_builderUtility class for building user-defined log messages with CAF_ARG
oCcaf::mailbox_category_corrector<>Corrects the message ID for down- and upstream messages to make sure the category for a mailbox_element matches its content
oCcaf::mailbox_element_vals< Ts >Encapsulates arbitrary data in a message element
oCcaf::mailbox_element_view< Ts >Provides a view for treating arbitrary data as message element
oCcaf::make_sink_result< In >Returns a stream sink with the slot ID of its first inbound path
oCcaf::make_source_result< DownstreamManager, Ts >Returns a stream source with the slot ID of its first outbound path
oCcaf::make_stage_result< In, DownstreamManager, Ts >Returns a stream stage with the slot IDs of its first in- and outbound paths
oCcaf::memory_managedThis base enables derived classes to enforce a different allocation strategy than new/delete by providing a virtual protected request_deletion() function and non-public destructor
oCcaf::message::cli_argStores the name of a command line option ("<long name>[,<short name>]") along with a description and a callback
oCcaf::message::cli_resStores the result of message::extract_opts
oCcaf::message_builderProvides a convenient interface for createing message objects from a series of values using the member function append
oCcaf::message_handlerA partial function implementation used to process a message
oCcaf::message_idBundles various flags along with an optional request ID
oCcaf::message_viewRepresents an object pointing to a type_erased_tuple that is convertible to a message
oCcaf::meta::annotationType tag for all meta annotations in CAF
oCcaf::mixin::behavior_changer< Base, Subtype >A behavior_changer is an actor that supports self->become(...) and self->unbecome()
oCcaf::mixin::requester< Base, Subtype >A requester is an actor that supports `self->request(...)
oCcaf::mixin::sender< Base, Subtype >A sender is an actor that supports self->send(...)
oCcaf::mixin::subscriber_baseMarker for subscriber
oCcaf::named_actor_configStores a flow-control configuration
oCcaf::no_error_tHelper class to construct an expected<T> that represents no error
oCcaf::no_stages_tConvenience tag type for producing empty forwarding stacks
oCcaf::node_idA node ID is an opaque value for representing CAF instances in the network
oCcaf::none_tRepresents "nothing", e.g., for clearing an optional by assigning none
oCcaf::open_stream_msgDemands the receiver to open a new stream from the sender to the receiver
oCcaf::optional< class >A C++17 compatible optional implementation
oCcaf::optional< T & >Template specialization to allow optional to hold a reference rather than an actual value with minimal overhead
oCcaf::outbound_pathState for a single path to a sink of a downstream_manager
oCcaf::outbound_stream_slot< OutputType, HandshakeArgs >Wraps a stream slot ID for outbound paths with the full type information of the path creation
oCcaf::output_stream< class, >Empty marker type for type-checking of stream sources and stages
oCcaf::param< class >Represents a message handler parameter of type T and guarantees copy-on-write semantics
oCcaf::param_decay< T >Convenience struct for remove_param<std::decay<T>>
oCcaf::policy::arg< Ts >Provides a wrapper to pass policy types as values to functions
oCcaf::policy::categorizedConfigures a cached WDRR fixed multiplexed queue for dispatching to four nested queue (one for each message category type)
oCcaf::policy::downstream_messagesConfigures a dynamic WDRR queue for holding downstream messages
oCcaf::policy::downstream_messages::nestedConfigures a nested DRR queue
oCcaf::policy::normal_messagesConfigures a cached DRR queue for holding asynchronous messages with default priority
oCcaf::policy::profiled< Policy >An enhancement of CAF's scheduling policy which records fine-grained resource utiliziation for worker threads and actors in the parent coordinator of the workers
oCcaf::policy::scheduler_policyThis concept class describes a policy for worker and coordinator of the scheduler
oCcaf::policy::scheduler_policy::coordinator_dataPolicy-specific data fields for the coordinator
oCcaf::policy::scheduler_policy::worker_dataPolicy-specific data fields for the worker
oCcaf::policy::unprofiledThis class is intended to be used as a base class for actual polices
oCcaf::policy::upstream_messagesConfigures a DRR queue for holding upstream messages
oCcaf::policy::urgent_messagesConfigures a cached DRR queue for holding asynchronous messages with default priority
oCcaf::proxy_registryGroups a (distributed) set of actors and allows actors in the same namespace to exchange messages
oCcaf::proxy_registry::backendResponsible for creating proxy actors
oCcaf::ratio_to_time_unit_helper< Num, Denom >Converts the ratio Num/Denom to a time_unit if the ratio describes seconds, milliseconds, microseconds, or minutes
oCcaf::remove_param< T >Unpacks param<T> to T
oCcaf::response_handle< Self, Output, IsBlocking >This helper class identifies an expected response message and enables request(...).then(...)
oCcaf::response_promiseA response promise can be used to deliver a uniquely identifiable response message from the server (i.e
oCcaf::response_type< Ts, Xs >Defines:
oCcaf::response_type_unbox< Ts, Xs >Unboxes Xs and calls response_type
oCcaf::resumableA cooperatively executed task managed by one or more instances of execution_unit
oCcaf::runtime_settings_mapThread-safe container for mapping atoms to arbitrary settings
oCcaf::scheduled_actor::mailbox_policyConfigures the FIFO inbox with four nested queues:
oCcaf::scheduled_actor::mailbox_visitorConsumes messages from the mailbox
oCcaf::scoped_actorA scoped handle to a blocking actor
oCcaf::select_callback< F, Args >Utility class for selecting a callback_impl
oCcaf::select_config_value_access< T, IsIntegral >Delegates to config_value_access for all specialized versions
oCcaf::select_config_value_access< T, true >Catches all non-specialized integer types
oCcaf::skip_t
oCcaf::span< class >A C++11/14 drop-in replacement for C++20's std::span without support for static extents
oCcaf::spawn_optionsStores options passed to the spawn function family
oCcaf::stateful_actor< class, class >An event-based actor with managed state
oCcaf::stream< class >Empty marker type for streaming handshakes
oCcaf::stream_buffer< CharT, Traits >The base class for all stream buffer implementations
oCcaf::stream_finalize_trait< Fun, State, AcceptsTwoArgs >Dispatches a finalize call to a function taking either one or two arguments
oCcaf::stream_finalize_trait< Fun, State, false >Specializes the trait for callbacks that only take the state
oCcaf::stream_finalize_trait< Fun, State, true >Specializes the trait for callbacks that take state and error
oCcaf::stream_sink_driver< Input >Identifies an unbound sequence of messages
oCcaf::stream_sink_trait< Fun >Defines required type aliases for stream sinks
oCcaf::stream_sink_trait_base< State, In >Base type for all sink traits
oCcaf::stream_slotsMaps two stream_slot values into a pair for storing sender and receiver slot information
oCcaf::stream_source_driver< DownstreamManager >Identifies an unbound sequence of messages
oCcaf::stream_source_trait< Pull >Deduces the output type and the state type for a stream source from its pull implementation
oCcaf::stream_stage_driver< Input, DownstreamManager >Encapsulates user-provided functionality for generating a stream stage
oCcaf::stream_stage_trait< void(State &, downstream< Out > &, In)>Deduces the input type, output type and the state type for a stream stage from its process implementation
oCcaf::string_viewDrop-in replacement for C++17 std::string_view
oCcaf::sum_type_access< T >Specializing this trait allows users to enable holds_alternative, get, get_if, and visit for any user-defined sum type
oCcaf::thread_hookInterface to define thread hooks
oCcaf::timeout_msgSignalizes a timeout event
oCcaf::type_erased_tupleRepresents a tuple of type-erased values
oCcaf::type_erased_valueRepresents a single type-erased value
oCcaf::type_erased_value_factory
oCcaf::type_nr< T, IsIntegral >Computes the type number for T
oCcaf::typed_actor<>Identifies a statically typed actor
oCcaf::typed_behavior< Sigs >::unsafe_initEmpty struct tag for constructing from an untyped behavior
oCcaf::typed_event_based_actor<>A cooperatively scheduled, event-based actor implementation with static type-checking
oCcaf::typed_response_promise<>A response promise can be used to deliver a uniquely identifiable response message from the server (i.e
oCcaf::unbox_message_element< T, IsPlaceholderRes >Unboxes atom constants, i.e., converts atom_constant<V> to V
oCcaf::unit_tUnit is analogous to void, but can be safely returned, stored, etc
oCcaf::upstream_msgStream messages that flow upstream, i.e., acks and drop messages
oCcaf::upstream_msg::ack_batchCumulatively acknowledges received batches and signalizes new demand from a sink to its source
oCcaf::upstream_msg::ack_openAcknowledges a previous open message and finalizes a stream handshake
oCcaf::upstream_msg::dropAsks the source to discard any remaining credit and close this path after receiving an ACK for the last batch
oCcaf::upstream_msg::forced_dropPropagates a fatal error from sinks to sources
oCcaf::uriA URI according to RFC 3986
oCcaf::uri::authority_typeBundles the authority component of the URI, i.e., userinfo, host, and port
oCcaf::variant<>A variant represents always a valid value of one of the types Ts...
oCcaf::variant_compare_helper< Predicate >
oCcaf::variant_reader< T >
oCcaf::variant_writer< T >
oCcaf::weak_intrusive_ptr< class >An intrusive, reference counting smart pointer implementation
oCcaf::callback< Ts...>
oCcaf::composable_behavior_base< Clauses >
oCcaf::composed_type< detail::type_list< typed_mpi< In, Out >, Xs...>, Ys, detail::type_list< Zs...>, Rs >
oCcaf::composed_type< detail::type_list< Xs...>, Ys, Ys, detail::type_list< Rs..., typed_mpi< detail::type_list< In...>, output_stream< M, Ms...> > > >
oCcaf::composed_type< detail::type_list< Xs...>, Ys, Ys, detail::type_list< Rs..., typed_mpi< detail::type_list< In...>, output_tuple< MapsTo...> > > >
oCcaf::composed_type< detail::type_list< Xs...>, Ys, Ys, Rs >
oCcaf::data_processor< deserializer >
oCcaf::data_processor< serializer >
oCcaf::io::network::datagram_handler_impl< policy::udp >
oCcaf::default_sum_type_access< variant< Ts...> >
oCcaf::dictionary< config_value >
oCcaf::expected< caf::config_value >
oCcaf::handle< accept_handle, invalid_accept_handle_t >
oCcaf::handle< connection_handle, invalid_connection_handle_t >
oCcaf::handle< datagram_handle, invalid_datagram_handle_t >
oCcaf::intrusive_cow_ptr< detail::dynamic_message_data >
oCcaf::intrusive_cow_ptr< impl >
oCcaf::intrusive_ptr< abstract_group >
oCcaf::intrusive_ptr< actor_control_block >
oCcaf::intrusive_ptr< caf::caf::logger >
oCcaf::intrusive_ptr< caf::io::scribe >
oCcaf::intrusive_ptr< caf::resumable >
oCcaf::intrusive_ptr< const detail::uri_impl >
oCcaf::intrusive_ptr< data >
oCcaf::intrusive_ptr< datagram_manager >
oCcaf::intrusive_ptr< datagram_servant >
oCcaf::intrusive_ptr< detail::behavior_impl >
oCcaf::intrusive_ptr< detail::uri_impl >
oCcaf::intrusive_ptr< doorman >
oCcaf::intrusive_ptr< manager_type >
oCcaf::intrusive_ptr< sink_type >
oCcaf::intrusive_ptr< source_type >
oCcaf::intrusive_ptr< stage_type >
oCcaf::intrusive_ptr< stream_manager >
oCcaf::intrusive_ptr< T >
oCcaf::mailbox_element_vals< SysMsgType >
oCcaf::optional< size_t >
oCcaf::response_type< detail::type_list< Ts...>, Xs...>
oCcaf::response_type< Ts, message >
oCcaf::response_type< Ts, Xs...>
oCcaf::stateful_actor< State, Base >
oCcaf::stream_buffer< Container::value_type, std::char_traits< Container::value_type > >
oCcaf::typed_actor< Ts...>
oCcaf::variant< ack_open, ack_batch, drop, forced_drop >
oCcaf::variant< batch, close, forced_close >
oCcaf::variant< std::string, ip_address >
\Ccaf::weak_intrusive_ptr< actor_control_block >