Ccaf::byte_address< ipv4_address > | |
Ccaf::byte_address< ipv6_address > | |
►Ccaf::abstract_channel | Interface for all message receivers |
►Ccaf::abstract_actor | Base class for all actor implementations |
►Ccaf::monitorable_actor | Base class for all actor implementations |
Ccaf::actor_pool | An actor poool is a lightweight abstraction for a set of workers |
►Ccaf::actor_proxy | Represents an actor running on a remote machine, or different hardware, or in a separate process |
Ccaf::forwarding_actor_proxy | Implements a simple proxy forwarding all operations to a manager |
Ccaf::abstract_group | A multicast group |
Ccaf::abstract_composable_behavior | Marker type that allows CAF to spawn actors from composable states |
Ccaf::actor | Identifies an untyped actor |
Ccaf::actor_addr | Stores the address of typed as well as untyped actors |
Ccaf::actor_clock | A monotonic clock for scheduling timeouts and delayed messages |
Ccaf::actor_companion | An 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 |
Ccaf::actor_config | Stores spawn-time flags and groups |
Ccaf::actor_control_block | Actors are always allocated with a control block that stores its identity as well as strong and weak reference counts to it |
Ccaf::actor_ostream | Provides support for thread-safe output operations on character streams |
Ccaf::actor_registry | A registry is used to associate actors to IDs or atoms (names) |
Ccaf::actor_system | Actor environment including scheduler, registry, and optional components such as a middleman |
►Ccaf::actor_system::module | An (optional) component of the actor system |
Ccaf::io::middleman | Manages brokers and network backends |
►Ccaf::scheduler::abstract_coordinator | A coordinator creates the workers, manages delayed sends and the central printer instance for aout |
►Ccaf::scheduler::coordinator< Policy > | Policy-based implementation of the abstract coordinator base class |
Ccaf::scheduler::profiled_coordinator< Policy > | A coordinator which keeps fine-grained profiling state about its workers and their jobs |
Ccaf::scheduler::test_coordinator | A schedule coordinator for testing purposes |
Ccaf::actor_system_config | Configures an actor_system on startup |
Ccaf::allowed_unsafe_message_type< T > | Template specializations can whitelist individual types for unsafe message passing operations |
Ccaf::atom_constant< V > | Lifts an atom_value to a compile-time constant |
Ccaf::attachable | Callback utility class |
Ccaf::attachable::token | Represents a pointer to a value with its subtype as type ID number |
Ccaf::behavior | Describes the behavior of an actor, i.e., provides a message handler and an optional timeout |
Ccaf::blocking_actor | A thread-mapped or context-switching actor using a blocking receive rather than a behavior-stack based message processing |
Ccaf::blocking_actor::do_receive_helper | Implementation helper for blocking_actor::do_receive |
Ccaf::blocking_actor::mailbox_policy | Configures the FIFO inbox with two nested queues: |
►Ccaf::blocking_actor::receive_cond | Represents pre- and postconditions for receive loops |
Ccaf::blocking_actor::accept_one_cond | Pseudo receive condition modeling a single receive |
Ccaf::blocking_actor::receive_for_helper< T > | Implementation helper for blocking_actor::receive_for |
Ccaf::blocking_actor::receive_while_helper | Implementation helper for blocking_actor::receive_while |
Ccaf::byte_address< Derived > | Base type for addresses based on a byte representation such as IP or Ethernet addresses |
Ccaf::callback< Ts > | Describes a simple callback, usually implemented via lambda expression |
Ccaf::composable_behavior< TypedActor > | Base type for composable actor states |
Ccaf::composable_behavior_base< MPI > | Generates an interface class that provides operator() |
Ccaf::composed_type< Xs, Ys, Zs, Rs > | Computes the type for f*g (actor composition) |
Ccaf::config_option | Defines a configuration option for the application |
Ccaf::config_option::meta_state | Custom vtable-like struct for delegating to type-specific functions and storing type-specific information shared by several config options |
Ccaf::config_option_adder | Adds config options of the same category to a config_option_set |
Ccaf::config_option_set | A set of config_option objects that parses CLI arguments into a config_value::dictionary |
Ccaf::config_value | A type for config parameters with similar interface to a variant |
Ccaf::config_value_access< T > | |
Ccaf::config_value_access< dictionary< V > > | Implements automagic unboxing of dictionary<V> from a homogeneous config_value::dictionary |
Ccaf::config_value_access< std::vector< T > > | Implements automagic unboxing of std::vector<T> from a homogeneous config_value::list |
Ccaf::cow_tuple< Ts > | A copy-on-write tuple implementation |
Ccaf::data_processor< Derived > | A data processor translates an object into a format that can be stored or vice versa |
Ccaf::default_downstream_manager< F > | Selects a downstream manager implementation based on the signature of various handlers |
Ccaf::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 |
Ccaf::delegated< Ts > | Helper class to indicate that a request has been forwarded |
Ccaf::dictionary< V > | Maps strings to values of type V , but unlike std::map<std::string, V> accepts string_view for looking up keys efficiently |
Ccaf::down_msg | Sent to all actors monitoring an actor when it is terminated |
Ccaf::downstream< T > | Grants access to an output stream buffer |
►Ccaf::downstream_manager | Manages downstream communication for a stream_manager |
►Ccaf::downstream_manager_base | The default downstream manager base stores outbound paths in an unordered map |
Ccaf::buffered_downstream_manager< T > | Mixin for streams with any number of downstreams |
Ccaf::fused_downstream_manager< T, Ts > | A downstream manager that delegates to any number of sub-managers |
Ccaf::downstream_manager::path_predicate | Predicate object for paths |
Ccaf::downstream_manager::path_visitor | Function object for iterating over all paths |
Ccaf::downstream_msg | Stream messages that travel downstream, i.e., batches and close messages |
Ccaf::downstream_msg::batch | Transmits stream data |
Ccaf::downstream_msg::close | Orderly shuts down a stream after receiving an ACK for the last batch |
Ccaf::downstream_msg::forced_close | Propagates a fatal error from sources to sinks |
Ccaf::duration | Time duration consisting of a time_unit and a 64 bit unsigned integer |
Ccaf::error | A serializable type for storing error codes with category and optional, human-readable context information |
►Ccaf::execution_unit | Identifies an execution unit, e.g., a worker thread of the scheduler |
Ccaf::io::network::multiplexer | Low-level backend for IO multiplexing |
Ccaf::scheduler::worker< Policy > | Policy-based implementation of the abstract worker base class |
Ccaf::scoped_execution_unit | Identifies an execution unit, e.g., a worker thread of the scheduler |
Ccaf::exit_msg | Sent to all links when an actor is terminated |
Ccaf::expected< T > | Represents the result of a computation which can either complete successfully with an instance of type T or fail with an error |
Ccaf::expected< void > | The pattern expected<void> shall be used for functions that may generate an error but would otherwise return bool |
Ccaf::extend< Base, Derived > | Allows convenient definition of types using mixins |
Ccaf::function_view< Actor > | A function view for an actor hides any messaging from the caller |
Ccaf::fused_downstream_manager< T, Ts >::non_owning_ptr | State held for each slot |
Ccaf::group_down_msg | Sent to all members of a group when it goes offline |
Ccaf::group_module | Interface for user-defined multicast implementations |
Ccaf::handle< Subtype, InvalidType, InvalidId > | Base class for IO handles such as accept_handle or connection_handle |
Ccaf::has_make_error< T > | Evaluates to true if T is an enum with a free function make_error for converting it to an error |
Ccaf::has_sum_type_access< T > | Evaluates to true if T specializes sum_type_access |
Ccaf::illegal_message_element | Marker class identifying classes in CAF that are not allowed to be used as message element |
Ccaf::inbound_path | State for a path to an upstream actor (source) |
Ccaf::inbound_path::stats_t | Stores statistics for measuring complexity of incoming batches |
Ccaf::inbound_path::stats_t::calculation_result | Wraps the resulf of stats_t::calculate() |
Ccaf::inbound_path::stats_t::measurement | Wraps a time measurement for a single processed batch |
Ccaf::inbound_stream_slot< In > | Wraps a stream slot ID for inbound paths with the full type information of the path creation |
Ccaf::index_mapping | Marker for representing placeholders at runtime |
Ccaf::infer_handle_from_class< T, bool > | Deduces actor for dynamically typed actors, otherwise typed_actor<...> is deduced |
Ccaf::infer_handle_from_fun< F, Trait > | Deduces an actor handle type from a function or function object |
Ccaf::infinite_t | Represents an infinite amount of timeout for specifying "invalid" timeouts |
Ccaf::intrusive_cow_ptr< T > | An intrusive, reference counting smart pointer implementation with copy-on-write optimization |
Ccaf::intrusive_ptr< T > | An intrusive, reference counting smart pointer implementation |
Ccaf::io::acceptor_closed_msg | Signalizes that a broker acceptor has been closed |
Ccaf::io::acceptor_passivated_msg | Signalizes that an acceptor has entered passive mode |
►Ccaf::io::broker_servant< Base, Handle, SysMsgType > | Base class for scribe and doorman |
►Ccaf::io::datagram_servant | Manages writing to a datagram sink |
Ccaf::io::network::datagram_servant_impl | Default datagram servant implementation |
►Ccaf::io::doorman | Manages incoming connections |
Ccaf::io::network::doorman_impl | Default doorman implementation |
►Ccaf::io::scribe | Manages a stream |
Ccaf::io::network::scribe_impl | Default scribe implementation |
Ccaf::io::connection_closed_msg | Signalizes that a broker connection has been closed |
Ccaf::io::connection_passivated_msg | Signalizes that a connection has entered passive mode |
Ccaf::io::data_transferred_msg | Signalizes that a certain amount of bytes has been written |
Ccaf::io::datagram_sent_msg | Signalizes that a datagram with a certain size has been sent |
Ccaf::io::datagram_servant_closed_msg | Signalizes that a datagram endpoint has entered passive mode |
Ccaf::io::datagram_servant_passivated_msg | Signalizes that a datagram sink has entered passive mode |
Ccaf::io::hook | Interface to define hooks into the IO layer |
Ccaf::io::network::datagram_handler_impl< ProtocolPolicy > | A concrete datagram_handler with a technology-dependent policy |
►Ccaf::io::network::event_handler | A socket I/O event handler |
►Ccaf::io::network::acceptor | An acceptor is responsible for accepting incoming connections |
Ccaf::io::network::acceptor_impl< policy::tcp > | |
Ccaf::io::network::acceptor_impl< ProtocolPolicy > | A concrete acceptor with a technology-dependent policy |
Ccaf::io::network::pipe_reader | An event handler for the internal event pipe |
►Ccaf::io::network::stream | A stream capable of both reading and writing |
Ccaf::io::network::stream_impl< ProtocolPolicy > | A concrete stream with a technology-dependent policy for sending and receiving data from a socket |
Ccaf::io::network::stream_impl< policy::tcp > | |
Ccaf::io::network::event_handler::state | Stores various status flags and user-defined config parameters |
Ccaf::io::network::interfaces | Utility class bundling access to network interface names and addresses |
Ccaf::io::network::ip_endpoint | A hashable wrapper for a sockaddr storage |
Ccaf::io::network::multiplexer::supervisor | Makes sure the multipler does not exit its event loop until the destructor of supervisor has been called |
Ccaf::io::network::protocol | Bundles protocol information for network and transport layer communication |
Ccaf::io::network::receive_buffer | A container that does not call constructors and destructors for its values |
Ccaf::io::new_connection_msg | Signalizes a newly accepted connection from a broker |
Ccaf::io::new_data_msg | Signalizes newly arrived data for a broker |
Ccaf::io::new_datagram_msg | Signalizes that a datagram with a certain size has been sent |
Ccaf::is_actor_handle< T > | Checks whether T is an actor or a typed_actor<...> |
Ccaf::is_typed_actor< T > | Evaluates to true if T is a typed_actor<...> |
Ccaf::logger::config | Combines various logging-related flags and parameters into a bitfield |
Ccaf::logger::event | Encapsulates a single logging event |
Ccaf::logger::field | Represents a single format string field |
Ccaf::logger::line_builder | Utility class for building user-defined log messages with CAF_ARG |
Ccaf::mailbox_category_corrector<... > | Corrects the message ID for down- and upstream messages to make sure the category for a mailbox_element matches its content |
Ccaf::mailbox_element_vals< Ts > | Encapsulates arbitrary data in a message element |
Ccaf::mailbox_element_view< Ts > | Provides a view for treating arbitrary data as message element |
Ccaf::make_sink_result< In > | Returns a stream sink with the slot ID of its first inbound path |
Ccaf::make_source_result< DownstreamManager, Ts > | Returns a stream source with the slot ID of its first outbound path |
Ccaf::make_stage_result< In, DownstreamManager, Ts > | Returns a stream stage with the slot IDs of its first in- and outbound paths |
►Ccaf::memory_managed | This 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 |
►Ccaf::ref_counted | Base class for reference counted objects with an atomic reference count |
Ccaf::abstract_group | A multicast group |
►Ccaf::io::network::manager | A manager configures an I/O device and provides callbacks for various I/O operations |
Ccaf::io::network::acceptor_manager | An acceptor manager configures an acceptor and provides callbacks for incoming connections as well as for error handling |
Ccaf::io::network::datagram_manager | A datagram manager provides callbacks for outgoing datagrams as well as for error handling |
Ccaf::io::network::stream_manager | A stream manager configures an IO stream and provides callbacks for incoming data as well as for error handling |
Ccaf::io::network::multiplexer::runnable | Simple wrapper for runnables |
Ccaf::logger | Centrally logs events from all actors in an actor system |
Ccaf::stream_manager | Manages a single stream with any number of in- and outbound paths |
Ccaf::message::cli_arg | Stores the name of a command line option ("<long name>[,<short name>]") along with a description and a callback |
Ccaf::message::cli_res | Stores the result of message::extract_opts |
Ccaf::message_builder | Provides a convenient interface for createing message objects from a series of values using the member function append |
Ccaf::message_handler | A partial function implementation used to process a message |
Ccaf::message_id | Bundles various flags along with an optional request ID |
Ccaf::message_view | Represents an object pointing to a type_erased_tuple that is convertible to a message |
Ccaf::meta::annotation | Type tag for all meta annotations in CAF |
Ccaf::mixin::behavior_changer< Base, Subtype > | A behavior_changer is an actor that supports self->become(...) and self->unbecome() |
Ccaf::mixin::requester< Base, Subtype > | A requester is an actor that supports `self->request(...) |
Ccaf::mixin::sender< Base, Subtype > | A sender is an actor that supports self->send(...) |
►Ccaf::mixin::subscriber_base | Marker for subscriber |
Ccaf::mixin::subscriber< Base, Subtype > | A subscriber is an actor that can subscribe to a group via self->join(...) |
Ccaf::named_actor_config | Stores a flow-control configuration |
Ccaf::no_error_t | Helper class to construct an expected<T> that represents no error |
Ccaf::no_stages_t | Convenience tag type for producing empty forwarding stacks |
Ccaf::node_id | A node ID consists of a host ID and process ID |
Ccaf::none_t | Represents "nothing", e.g., for clearing an optional by assigning none |
Ccaf::open_stream_msg | Demands the receiver to open a new stream from the sender to the receiver |
Ccaf::optional< T > | A C++17 compatible optional implementation |
Ccaf::optional< T & > | Template specialization to allow optional to hold a reference rather than an actual value with minimal overhead |
Ccaf::outbound_path | State for a single path to a sink of a downstream_manager |
Ccaf::outbound_stream_slot< OutputType, HandshakeArgs > | Wraps a stream slot ID for outbound paths with the full type information of the path creation |
Ccaf::output_stream< T, Ts > | Empty marker type for type-checking of stream sources and stages |
Ccaf::param< T > | Represents a message handler parameter of type T and guarantees copy-on-write semantics |
Ccaf::param_decay< T > | Convenience struct for remove_param<std::decay<T>> |
Ccaf::policy::arg< Ts > | Provides a wrapper to pass policy types as values to functions |
Ccaf::policy::categorized | Configures a cached WDRR fixed multiplexed queue for dispatching to four nested queue (one for each message category type) |
Ccaf::policy::downstream_messages | Configures a dynamic WDRR queue for holding downstream messages |
Ccaf::policy::downstream_messages::nested | Configures a nested DRR queue |
Ccaf::policy::normal_messages | Configures a cached DRR queue for holding asynchronous messages with default priority |
Ccaf::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 |
►Ccaf::policy::scheduler_policy | This concept class describes a policy for worker and coordinator of the scheduler |
Ccaf::policy::work_sharing | Implements scheduling of actors via work sharing (central job queue) |
Ccaf::policy::work_stealing | Implements scheduling of actors via work stealing |
Ccaf::policy::scheduler_policy::coordinator_data | Policy-specific data fields for the coordinator |
Ccaf::policy::scheduler_policy::worker_data | Policy-specific data fields for the worker |
►Ccaf::policy::unprofiled | This class is intended to be used as a base class for actual polices |
Ccaf::policy::work_sharing | Implements scheduling of actors via work sharing (central job queue) |
Ccaf::policy::work_stealing | Implements scheduling of actors via work stealing |
Ccaf::policy::upstream_messages | Configures a DRR queue for holding upstream messages |
Ccaf::policy::urgent_messages | Configures a cached DRR queue for holding asynchronous messages with default priority |
Ccaf::proxy_registry | Groups a (distributed) set of actors and allows actors in the same namespace to exchange messages |
Ccaf::proxy_registry::backend | Responsible for creating proxy actors |
Ccaf::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 |
Ccaf::remove_param< T > | Unpacks param<T> to T |
Ccaf::response_handle< Self, Output, IsBlocking > | This helper class identifies an expected response message and enables request(...).then(...) |
Ccaf::response_promise | A response promise can be used to deliver a uniquely identifiable response message from the server (i.e |
Ccaf::response_type< Ts, Xs > | Defines: |
Ccaf::response_type_unbox< Ts, Xs > | Unboxes Xs and calls response_type |
►Ccaf::resumable | A cooperatively executed task managed by one or more instances of execution_unit |
Ccaf::io::network::multiplexer::runnable | Simple wrapper for runnables |
►Ccaf::scheduled_actor | A cooperatively scheduled, event-based actor implementation |
►Ccaf::event_based_actor | A cooperatively scheduled, event-based actor implementation |
Ccaf::raw_event_based_actor | A cooperatively raw scheduled actor is a dynamically typed actor that does not handle any system messages |
Ccaf::raw_event_based_actor | A cooperatively raw scheduled actor is a dynamically typed actor that does not handle any system messages |
►Ccaf::io::abstract_broker | A broker mediates between actor systems and other components in the network |
Ccaf::io::broker | Describes a dynamically typed broker |
Ccaf::runtime_settings_map | Thread-safe container for mapping atoms to arbitrary settings |
Ccaf::scheduled_actor::mailbox_policy | Configures the FIFO inbox with four nested queues: |
Ccaf::scheduled_actor::mailbox_visitor | Consumes messages from the mailbox |
Ccaf::scoped_actor | A scoped handle to a blocking actor |
Ccaf::select_callback< F, Args > | Utility class for selecting a callback_impl |
Ccaf::select_config_value_access< T, IsIntegral > | Delegates to config_value_access for all specialized versions |
Ccaf::select_config_value_access< T, true > | Catches all non-specialized integer types |
Ccaf::skip_t | |
Ccaf::spawn_options | Stores options passed to the spawn function family |
►Ccaf::stateful_actor< State, Base > | An event-based actor with managed state |
Ccaf::composable_behavior_based_actor< State, Base > | Implementation class for spawning composable states directly as actors |
Ccaf::stream< T > | Empty marker type for streaming handshakes |
►Ccaf::stream_buffer< CharT, Traits > | The base class for all stream buffer implementations |
Ccaf::arraybuf< CharT, Traits > | A streambuffer abstraction over a fixed array of bytes |
Ccaf::stream_finalize_trait< Fun, State, AcceptsTwoArgs > | Dispatches a finalize call to a function taking either one or two arguments |
Ccaf::stream_finalize_trait< Fun, State, false > | Specializes the trait for callbacks that only take the state |
Ccaf::stream_finalize_trait< Fun, State, true > | Specializes the trait for callbacks that take state and error |
Ccaf::stream_sink_driver< Input > | Identifies an unbound sequence of messages |
Ccaf::stream_sink_trait< Fun > | Defines required type aliases for stream sinks |
►Ccaf::stream_sink_trait_base< State, In > | Base type for all sink traits |
Ccaf::stream_sink_trait< void(State &, const std::vector< In > &)> | Specializes the trait for batch-wise processing with const references |
Ccaf::stream_sink_trait< void(State &, In)> | Specializes the trait for element-wise processing |
Ccaf::stream_sink_trait< void(State &, std::vector< In > &)> | Specializes the trait for batch-wise processing |
Ccaf::stream_slots | Maps two stream_slot values into a pair for storing sender and receiver slot information |
Ccaf::stream_source_driver< DownstreamManager > | Identifies an unbound sequence of messages |
Ccaf::stream_source_trait< Pull > | Deduces the output type and the state type for a stream source from its pull implementation |
Ccaf::stream_stage_driver< Input, DownstreamManager > | Encapsulates user-provided functionality for generating a stream stage |
Ccaf::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 |
Ccaf::string_view | Drop-in replacement for C++17 std::string_view |
Ccaf::sum_type_access< T > | Specializing this trait allows users to enable holds_alternative , get , get_if , and visit for any user-defined sum type |
Ccaf::thread_hook | Interface to define thread hooks |
Ccaf::timeout_msg | Signalizes a timeout event |
►Ccaf::type_erased_tuple | Represents a tuple of type-erased values |
Ccaf::empty_type_erased_tuple | |
Ccaf::message | Describes a fixed-length, copy-on-write, type-erased tuple with elements of any type |
Ccaf::type_erased_value | Represents a single type-erased value |
Ccaf::type_erased_value_factory | |
Ccaf::type_nr< T, IsIntegral > | Computes the type number for T |
Ccaf::typed_actor< Sigs > | Identifies a statically typed actor |
Ccaf::typed_behavior< Sigs >::unsafe_init | Empty struct tag for constructing from an untyped behavior |
►Ccaf::typed_event_based_actor< Sigs > | A cooperatively scheduled, event-based actor implementation with static type-checking |
Ccaf::io::middleman_actor_impl | Default implementation of the middleman_actor interface |
Ccaf::typed_response_promise< Ts > | A response promise can be used to deliver a uniquely identifiable response message from the server (i.e |
Ccaf::unbox_message_element< T, IsPlaceholderRes > | Unboxes atom constants, i.e., converts atom_constant<V> to V |
Ccaf::unit_t | Unit is analogous to void , but can be safely returned, stored, etc |
Ccaf::unsafe_actor_handle_init_t | Tag type to select the unsafe constructor of actor handles |
Ccaf::upstream_msg | Stream messages that flow upstream, i.e., acks and drop messages |
Ccaf::upstream_msg::ack_batch | Cumulatively acknowledges received batches and signalizes new demand from a sink to its source |
Ccaf::upstream_msg::ack_open | Acknowledges a previous open message and finalizes a stream handshake |
Ccaf::upstream_msg::drop | Asks the source to discard any remaining credit and close this path after receiving an ACK for the last batch |
Ccaf::upstream_msg::forced_drop | Propagates a fatal error from sinks to sources |
Ccaf::uri | A URI according to RFC 3986 |
Ccaf::uri::authority_type | Bundles the authority component of the URI, i.e., userinfo, host, and port |
Ccaf::variant< Ts > | A variant represents always a valid value of one of the types Ts... |
Ccaf::variant_compare_helper< Predicate > | |
Ccaf::variant_reader< T > | |
Ccaf::variant_writer< T > | |
Ccaf::weak_intrusive_ptr< T > | An intrusive, reference counting smart pointer implementation |
►Ccaf::callback< Ts... > | |
Ccaf::callback_impl< F, Ts > | Utility class for wrapping a function object of type Base |
Ccaf::composable_behavior_base< Clauses > | |
Ccaf::composed_type< detail::type_list< typed_mpi< In, Out >, Xs... >, Ys, detail::type_list< Zs... >, Rs > | |
Ccaf::composed_type< detail::type_list< Xs... >, Ys, Ys, detail::type_list< Rs..., typed_mpi< detail::type_list< In... >, output_stream< M, Ms... > > > > | |
Ccaf::composed_type< detail::type_list< Xs... >, Ys, Ys, detail::type_list< Rs..., typed_mpi< detail::type_list< In... >, output_tuple< MapsTo... > > > > | |
Ccaf::composed_type< detail::type_list< Xs... >, Ys, Ys, Rs > | |
►Ccaf::data_processor< deserializer > | |
►Ccaf::deserializer | Technology-independent deserialization interface |
Ccaf::stream_deserializer< Streambuf > | Implements the deserializer interface with a binary serialization protocol |
►Ccaf::data_processor< serializer > | |
►Ccaf::serializer | Technology-independent serialization interface |
Ccaf::stream_serializer< Streambuf > | Implements the serializer interface with a binary serialization protocol |
Ccaf::io::network::datagram_handler_impl< policy::udp > | |
►Ccaf::default_sum_type_access< variant< Ts... > > | |
Ccaf::sum_type_access< variant< Ts... > > | Enable holds_alternative , get , get_if , and visit for variant |
Ccaf::dictionary< caf::dictionary > | |
►Ccaf::handle< accept_handle, invalid_accept_handle_t > | |
Ccaf::io::accept_handle | Generic handle type for managing incoming connections |
►Ccaf::handle< connection_handle, invalid_connection_handle_t > | |
Ccaf::io::connection_handle | Generic handle type for identifying connections |
►Ccaf::handle< datagram_handle, invalid_datagram_handle_t > | |
Ccaf::io::datagram_handle | Generic handle type for identifying datagram endpoints |
Ccaf::intrusive_cow_ptr< detail::dynamic_message_data > | |
Ccaf::intrusive_cow_ptr< impl > | |
Ccaf::intrusive_ptr< abstract_group > | |
Ccaf::intrusive_ptr< actor_control_block > | |
Ccaf::intrusive_ptr< caf::io::scribe > | |
Ccaf::intrusive_ptr< caf::logger > | |
Ccaf::intrusive_ptr< caf::resumable > | |
Ccaf::intrusive_ptr< const detail::uri_impl > | |
Ccaf::intrusive_ptr< data > | |
Ccaf::intrusive_ptr< datagram_manager > | |
Ccaf::intrusive_ptr< datagram_servant > | |
Ccaf::intrusive_ptr< detail::behavior_impl > | |
Ccaf::intrusive_ptr< detail::dynamic_message_data > | |
Ccaf::intrusive_ptr< detail::uri_impl > | |
Ccaf::intrusive_ptr< doorman > | |
Ccaf::intrusive_ptr< impl > | |
Ccaf::intrusive_ptr< manager_type > | |
Ccaf::intrusive_ptr< scribe > | |
Ccaf::intrusive_ptr< sink_type > | |
Ccaf::intrusive_ptr< source_type > | |
Ccaf::intrusive_ptr< stage_type > | |
Ccaf::intrusive_ptr< stream_manager > | |
Ccaf::mailbox_element_vals< SysMsgType > | |
Ccaf::optional< size_t > | |
Ccaf::response_type< detail::type_list< Ts... >, Xs... > | |
Ccaf::response_type< Ts, message > | |
Ccaf::response_type< Ts, Xs... > | |
►Ccaf::stateful_actor< basp_broker_state, broker > | |
Ccaf::io::basp_broker | A broker implementation for the Binary Actor System Protocol (BASP) |
►Ccaf::stream_buffer< Container::value_type, std::char_traits< Container::value_type > > | |
Ccaf::containerbuf< Container > | A streambuffer abstraction over a contiguous container |
Ccaf::typed_actor< replies_to< publish_atom, uint16_t, strong_actor_ptr, std::set< std::string >, std::string, bool > ::with< uint16_t >, replies_to< publish_udp_atom, uint16_t, strong_actor_ptr, std::set< std::string >, std::string, bool > ::with< uint16_t >, replies_to< open_atom, uint16_t, std::string, bool > ::with< uint16_t >, replies_to< connect_atom, std::string, uint16_t > ::with< node_id, strong_actor_ptr, std::set< std::string > >, replies_to< contact_atom, std::string, uint16_t > ::with< node_id, strong_actor_ptr, std::set< std::string > >, reacts_to< unpublish_atom, actor_addr, uint16_t >, reacts_to< unpublish_udp_atom, actor_addr, uint16_t >, reacts_to< close_atom, uint16_t >, replies_to< spawn_atom, node_id, std::string, message, std::set< std::string > > ::with< strong_actor_ptr >, replies_to< get_atom, node_id >::with< node_id, std::string, uint16_t > > | |
Ccaf::typed_actor< Ts... > | |
Ccaf::variant< ack_open, ack_batch, drop, forced_drop > | |
Ccaf::variant< batch, close, forced_close > | |
Ccaf::variant< std::string, ip_address > | |
Ccaf::weak_intrusive_ptr< actor_control_block > | |