Index _ | A | B | C | D | E | F | G | H | I | K | L | M | N | O | P | R | S | T | U | V | W | Z _ _addr_to_future (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) _instance (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) _lock (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) A actor_to_remove (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) add() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) add_actor() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) add_callback_info_to_model() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) add_command() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) add_handler() (p2pfl.management.logger.logger.P2PFLogger method) add_info() (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) add_log() (p2pfl.management.metric_storage.GlobalMetricStorage method) (p2pfl.management.metric_storage.LocalMetricStorage method) add_message() (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.management.message_storage.MessageStorage method) add_model() (p2pfl.learning.aggregators.aggregator.Aggregator method) add_NodeServicesServicer_to_server() (in module p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc) addr (p2pfl.node_state.NodeState attribute) AddressCounter (class in p2pfl.communication.protocols.protobuff.memory.server) AddressParser (class in p2pfl.communication.protocols.protobuff.grpc.address) aggregate() (p2pfl.learning.aggregators.aggregator.Aggregator method) (p2pfl.learning.aggregators.fedavg.FedAvg method) (p2pfl.learning.aggregators.fedmedian.FedMedian method) (p2pfl.learning.aggregators.scaffold.Scaffold method) AGGREGATION_TIMEOUT (p2pfl.settings.Training attribute) Aggregator (class in p2pfl.learning.aggregators.aggregator) AMOUNT_LAST_MESSAGES_SAVED (p2pfl.settings.Gossip attribute) apply() (p2pfl.learning.compression.manager.CompressionManager static method) apply_gradients() (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.ScaffoldOptimizerWrapper method) apply_strategy() (p2pfl.learning.compression.base_compression_strategy.ByteCompressor method) (p2pfl.learning.compression.base_compression_strategy.CompressionStrategy method) (p2pfl.learning.compression.base_compression_strategy.TensorCompressor method) (p2pfl.learning.compression.lra_strategy.LowRankApproximation method) (p2pfl.learning.compression.lzma_strategy.LZMACompressor method) (p2pfl.learning.compression.quantization_strategy.PTQuantization method) (p2pfl.learning.compression.topk_strategy.TopKSparsification method) (p2pfl.learning.compression.zlib_strategy.ZlibCompressor method) assert_running() (p2pfl.node.Node method) B BASE_DIR (p2pfl.settings.SSL attribute) beat() (p2pfl.communication.protocols.protobuff.heartbeater.Heartbeater method) bluid_client() (p2pfl.communication.protocols.protobuff.grpc.GrpcCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.memory.MemoryCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) broadcast() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) build_copy() (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) build_msg() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) build_server() (p2pfl.communication.protocols.protobuff.grpc.GrpcCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.memory.MemoryCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) build_weights() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) ByteCompressor (class in p2pfl.learning.compression.base_compression_strategy) C CA_CRT (p2pfl.settings.SSL attribute) CallbackFactory (class in p2pfl.learning.frameworks.callback_factory) check_and_set_processed() (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) check_client_resources() (in module p2pfl.learning.frameworks.simulation.utils) check_early_stop() (in module p2pfl.stages.stage) cleanup() (p2pfl.management.logger.logger.P2PFLogger method) clear() (p2pfl.learning.aggregators.aggregator.Aggregator method) (p2pfl.node_state.NodeState method) clear_neighbors() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) CLIENT_CRT (p2pfl.settings.SSL attribute) CLIENT_KEY (p2pfl.settings.SSL attribute) ColoredFormatter (class in p2pfl.management.logger.logger) Command (class in p2pfl.communication.commands.command) CommunicationError CommunicationProtocol (class in p2pfl.communication.protocols.communication_protocol) CompressionManager (class in p2pfl.learning.compression.manager) CompressionStrategy (class in p2pfl.learning.compression.base_compression_strategy) connect() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) (p2pfl.communication.protocols.protobuff.grpc.client.GrpcClient method) (p2pfl.communication.protocols.protobuff.memory.client.MemoryClient method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.node.Node method) connect_web() (p2pfl.management.logger.logger.P2PFLogger method) create_actor() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) create_callbacks() (p2pfl.learning.frameworks.callback_factory.CallbackFactory class method) create_learner() (p2pfl.learning.frameworks.learner_factory.LearnerFactory class method) critical() (p2pfl.management.logger.logger.P2PFLogger method) D DataExportStrategy (class in p2pfl.learning.dataset.p2pfl_dataset) DataPartitionStrategy (class in p2pfl.learning.dataset.partition_strategies) debug() (p2pfl.management.logger.logger.P2PFLogger method) decode_parameters() (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) DecodingParamsError DEFAULT_BATCH_SIZE (p2pfl.settings.Training attribute) description (p2pfl.management.cli.ExampleInfo attribute) DirichletPartitionStrategy (class in p2pfl.learning.dataset.partition_strategies) DISABLE_RAY (p2pfl.settings.General attribute) disconnect() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) (p2pfl.communication.protocols.protobuff.grpc.client.GrpcClient method) (p2pfl.communication.protocols.protobuff.memory.client.MemoryClient method) (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServices static method) (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServicesServicer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) (p2pfl.node.Node method) E EarlyStopException encode_parameters() (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) error() (p2pfl.management.logger.logger.P2PFLogger method) evaluate() (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner method) (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.pytorch.lightning_learner.LightningLearner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) ExampleInfo (class in p2pfl.management.cli) EXCLUDE_BEAT_LOGS (p2pfl.settings.Heartbeat attribute) execute() (p2pfl.communication.commands.command.Command method) (p2pfl.communication.commands.message.heartbeat_command.HeartbeatCommand method) (p2pfl.communication.commands.message.metrics_command.MetricsCommand method) (p2pfl.communication.commands.message.model_initialized_command.ModelInitializedCommand method) (p2pfl.communication.commands.message.models_agregated_command.ModelsAggregatedCommand method) (p2pfl.communication.commands.message.models_ready_command.ModelsReadyCommand method) (p2pfl.communication.commands.message.start_learning_command.StartLearningCommand method) (p2pfl.communication.commands.message.stop_learning_command.StopLearningCommand method) (p2pfl.communication.commands.message.vote_train_set_command.VoteTrainSetCommand method) (p2pfl.communication.commands.weights.full_model_command.FullModelCommand method) (p2pfl.communication.commands.weights.init_model_command.InitModelCommand method) (p2pfl.communication.commands.weights.partial_model_command.PartialModelCommand method) (p2pfl.stages.base_node.gossip_model_stage.GossipModelStage static method) (p2pfl.stages.base_node.round_finished_stage.RoundFinishedStage static method) (p2pfl.stages.base_node.start_learning_stage.StartLearningStage static method) (p2pfl.stages.base_node.train_stage.TrainStage static method) (p2pfl.stages.base_node.vote_train_set_stage.VoteTrainSetStage static method) (p2pfl.stages.base_node.wait_agg_models_stage.WaitAggregatedModelsStage static method) (p2pfl.stages.stage.Stage static method) exists() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) EXIT_ON_X_EQUAL_ROUNDS (p2pfl.settings.Gossip attribute) exp_name (p2pfl.experiment.Experiment attribute) (p2pfl.node_state.NodeState attribute) (p2pfl.node_state.NodeState property) Experiment (class in p2pfl.experiment) experiment_finished() (p2pfl.management.logger.logger.P2PFLogger method) experiment_started() (p2pfl.management.logger.logger.P2PFLogger method) experiment_updated() (p2pfl.management.logger.logger.P2PFLogger method) export() (p2pfl.learning.dataset.p2pfl_dataset.DataExportStrategy static method) (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) (p2pfl.learning.frameworks.flax.flax_dataset.FlaxExportStrategy static method) (p2pfl.learning.frameworks.pytorch.lightning_dataset.PyTorchExportStrategy static method) (p2pfl.learning.frameworks.tensorflow.keras_dataset.KerasExportStrategy static method) F FedAvg (class in p2pfl.learning.aggregators.fedavg) FederatedLogger (class in p2pfl.learning.frameworks.pytorch.lightning_logger) (class in p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger) FedMedian (class in p2pfl.learning.aggregators.fedmedian) finalize() (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger method) fit() (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner method) (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.pytorch.lightning_learner.LightningLearner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) FLAX (p2pfl.learning.frameworks.Framework attribute) flax_model (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner property) FlaxExportStrategy (class in p2pfl.learning.frameworks.flax.flax_dataset) FlaxLearner (class in p2pfl.learning.frameworks.flax.flax_learner) FlaxModel (class in p2pfl.learning.frameworks.flax.flax_model) format() (p2pfl.management.logger.logger.ColoredFormatter method) Framework (class in p2pfl.learning.frameworks) from_csv() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) from_generator() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) from_huggingface() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) from_json() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) from_pandas() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) from_parquet() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset class method) FullModelCommand (class in p2pfl.communication.commands.weights.full_model_command) G General (class in p2pfl.settings) general (p2pfl.settings.Settings attribute) generate_partitions() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) (p2pfl.learning.dataset.partition_strategies.DataPartitionStrategy static method) (p2pfl.learning.dataset.partition_strategies.DirichletPartitionStrategy class method) (p2pfl.learning.dataset.partition_strategies.LabelSkewedPartitionStrategy static method) (p2pfl.learning.dataset.partition_strategies.RandomIIDPartitionStrategy static method) generate_train_test_split() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) get() (p2pfl.communication.protocols.protobuff.memory.server.AddressCounter method) (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) get_address() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) get_aggregated_models() (p2pfl.learning.aggregators.aggregator.Aggregator method) get_all() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) get_all_logs() (p2pfl.management.metric_storage.GlobalMetricStorage method) (p2pfl.management.metric_storage.LocalMetricStorage method) get_contributors() (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) get_data() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.node.Node method) get_experiment_logs() (p2pfl.management.metric_storage.GlobalMetricStorage method) (p2pfl.management.metric_storage.LocalMetricStorage method) get_experiment_node_logs() (p2pfl.management.metric_storage.GlobalMetricStorage method) get_experiment_round_logs() (p2pfl.management.metric_storage.LocalMetricStorage method) get_experiment_round_node_logs() (p2pfl.management.metric_storage.LocalMetricStorage method) get_framework() (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner method) (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) (p2pfl.learning.frameworks.pytorch.lightning_learner.LightningLearner method) (p2pfl.learning.frameworks.pytorch.lightning_model.LightningModel method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) (p2pfl.learning.frameworks.tensorflow.keras_model.KerasModel method) get_global_logs() (p2pfl.management.logger.logger.P2PFLogger method) get_info() (p2pfl.learning.frameworks.callback.P2PFLCallback method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) get_learner_result() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) get_level() (p2pfl.management.logger.logger.P2PFLogger method) get_level_name() (p2pfl.management.logger.logger.P2PFLogger method) get_local_logs() (p2pfl.management.logger.logger.P2PFLogger method) get_logs() (p2pfl.management.node_monitor.NodeMonitor method) get_messages() (p2pfl.management.logger.logger.P2PFLogger method) (p2pfl.management.message_storage.MessageStorage method) get_missing_models() (p2pfl.learning.aggregators.aggregator.Aggregator method) get_mnist() (p2pfl.learning.frameworks.pytorch.lightning_dataset.TorchvisionDatasetFactory static method) get_model() (p2pfl.learning.aggregators.aggregator.Aggregator method) (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.node.Node method) get_name() (p2pfl.communication.commands.command.Command static method) (p2pfl.communication.commands.message.heartbeat_command.HeartbeatCommand static method) (p2pfl.communication.commands.message.metrics_command.MetricsCommand static method) (p2pfl.communication.commands.message.model_initialized_command.ModelInitializedCommand static method) (p2pfl.communication.commands.message.models_agregated_command.ModelsAggregatedCommand static method) (p2pfl.communication.commands.message.models_ready_command.ModelsReadyCommand static method) (p2pfl.communication.commands.message.start_learning_command.StartLearningCommand static method) (p2pfl.communication.commands.message.stop_learning_command.StopLearningCommand static method) (p2pfl.communication.commands.message.vote_train_set_command.VoteTrainSetCommand static method) (p2pfl.communication.commands.weights.full_model_command.FullModelCommand static method) (p2pfl.communication.commands.weights.init_model_command.InitModelCommand static method) (p2pfl.communication.commands.weights.partial_model_command.PartialModelCommand static method) (p2pfl.learning.frameworks.callback.P2PFLCallback static method) (p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback.SCAFFOLDCallback static method) (p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger.FederatedLogger static method) (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.SCAFFOLDCallback static method) get_neighbors() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.node.Node method) get_nodes() (p2pfl.management.logger.logger.P2PFLogger method) get_num_samples() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) get_parameters() (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) (p2pfl.learning.frameworks.pytorch.lightning_model.LightningModel method) (p2pfl.learning.frameworks.tensorflow.keras_model.KerasModel method) get_parsed_address() (p2pfl.communication.protocols.protobuff.grpc.address.AddressParser method) get_pending_actions() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) get_received_messages() (p2pfl.management.message_storage.MessageStorage method) get_registry() (p2pfl.learning.compression.manager.CompressionManager static method) get_required_callbacks() (p2pfl.learning.aggregators.aggregator.Aggregator method) (p2pfl.learning.aggregators.scaffold.Scaffold method) get_sent_messages() (p2pfl.management.message_storage.MessageStorage method) get_stage() (p2pfl.stages.stage_factory.StageFactory static method) get_system_metrics() (p2pfl.management.logger.logger.P2PFLogger method) GlobalMetricStorage (class in p2pfl.management.metric_storage) Gossip (class in p2pfl.settings) gossip (p2pfl.settings.Settings attribute) gossip_weights() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) Gossiper (class in p2pfl.communication.protocols.protobuff.gossiper) GossipModelStage (class in p2pfl.stages.base_node.gossip_model_stage) GRPC_TIMEOUT (p2pfl.settings.General attribute) GrpcClient (class in p2pfl.communication.protocols.protobuff.grpc.client) GrpcCommunicationProtocol (class in p2pfl.communication.protocols.protobuff.grpc) GrpcServer (class in p2pfl.communication.protocols.protobuff.grpc.server) H handshake() (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServices static method) (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServicesServicer method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) has_temporal_connection() (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) Heartbeat (class in p2pfl.settings) heartbeat (p2pfl.settings.Settings attribute) HeartbeatCommand (class in p2pfl.communication.commands.message.heartbeat_command) Heartbeater (class in p2pfl.communication.protocols.protobuff.heartbeater) I increase_round() (p2pfl.experiment.Experiment method) (p2pfl.node_state.NodeState method) indicate_aggregator() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) info() (p2pfl.management.logger.logger.P2PFLogger method) initialized (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) InitModelCommand (class in p2pfl.communication.commands.weights.init_model_command) interrupt_fit() (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner method) (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.pytorch.lightning_learner.LightningLearner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) is_connected() (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) (p2pfl.communication.protocols.protobuff.grpc.client.GrpcClient method) (p2pfl.communication.protocols.protobuff.memory.client.MemoryClient method) is_running() (p2pfl.communication.protocols.protobuff.grpc.server.GrpcServer method) (p2pfl.communication.protocols.protobuff.memory.server.MemoryServer method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) K KerasExportStrategy (class in p2pfl.learning.frameworks.tensorflow.keras_dataset) KerasLearner (class in p2pfl.learning.frameworks.tensorflow.keras_learner) KerasModel (class in p2pfl.learning.frameworks.tensorflow.keras_model) L LabelSkewedPartitionStrategy (class in p2pfl.learning.dataset.partition_strategies) Learner (class in p2pfl.learning.frameworks.learner) learner (p2pfl.node_state.NodeState attribute) LearnerFactory (class in p2pfl.learning.frameworks.learner_factory) LearnerRunningException LearningWorkflow (class in p2pfl.stages.workflows) LightningLearner (class in p2pfl.learning.frameworks.pytorch.lightning_learner) LightningModel (class in p2pfl.learning.frameworks.pytorch.lightning_model) list_examples() (in module p2pfl.management.cli) load_by_package_and_name() (in module p2pfl.management.launch_from_yaml) LocalMetricStorage (class in p2pfl.management.metric_storage) lock (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) log() (p2pfl.management.logger.logger.P2PFLogger method) log_communication() (p2pfl.management.logger.logger.P2PFLogger method) LOG_DIR (p2pfl.settings.General attribute) log_hyperparams() (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger method) LOG_LEVEL (p2pfl.settings.General attribute) log_metric() (p2pfl.management.logger.logger.P2PFLogger method) log_metrics() (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger method) log_successful_send() (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) login() (in module p2pfl.management.cli) LowRankApproximation (class in p2pfl.learning.compression.lra_strategy) LZMACompressor (class in p2pfl.learning.compression.lzma_strategy) M MAX_LOG_RUNS (p2pfl.settings.General attribute) MemoryClient (class in p2pfl.communication.protocols.protobuff.memory.client) MemoryCommunicationProtocol (class in p2pfl.communication.protocols.protobuff.memory) MemoryServer (class in p2pfl.communication.protocols.protobuff.memory.server) MESSAGES_PER_PERIOD (p2pfl.settings.Gossip attribute) MessageStorage (class in p2pfl.management.message_storage) MetricsCommand (class in p2pfl.communication.commands.message.metrics_command) model_initialized_lock (p2pfl.node_state.NodeState attribute) ModelInitializedCommand (class in p2pfl.communication.commands.message.model_initialized_command) ModelNotBuiltError ModelNotMatchingError models_aggregated (p2pfl.node_state.NodeState attribute) MODELS_PER_ROUND (p2pfl.settings.Gossip attribute) MODELS_PERIOD (p2pfl.settings.Gossip attribute) ModelsAggregatedCommand (class in p2pfl.communication.commands.message.models_agregated_command) ModelsReadyCommand (class in p2pfl.communication.commands.message.models_ready_command) module p2pfl p2pfl.communication p2pfl.communication.commands p2pfl.communication.commands.command p2pfl.communication.commands.message p2pfl.communication.commands.message.heartbeat_command p2pfl.communication.commands.message.metrics_command p2pfl.communication.commands.message.model_initialized_command p2pfl.communication.commands.message.models_agregated_command p2pfl.communication.commands.message.models_ready_command p2pfl.communication.commands.message.start_learning_command p2pfl.communication.commands.message.stop_learning_command p2pfl.communication.commands.message.vote_train_set_command p2pfl.communication.commands.weights p2pfl.communication.commands.weights.full_model_command p2pfl.communication.commands.weights.init_model_command p2pfl.communication.commands.weights.partial_model_command p2pfl.communication.protocols p2pfl.communication.protocols.communication_protocol p2pfl.communication.protocols.exceptions p2pfl.communication.protocols.protobuff p2pfl.communication.protocols.protobuff.client p2pfl.communication.protocols.protobuff.gossiper p2pfl.communication.protocols.protobuff.grpc p2pfl.communication.protocols.protobuff.grpc.address p2pfl.communication.protocols.protobuff.grpc.client p2pfl.communication.protocols.protobuff.grpc.server p2pfl.communication.protocols.protobuff.heartbeater p2pfl.communication.protocols.protobuff.memory p2pfl.communication.protocols.protobuff.memory.client p2pfl.communication.protocols.protobuff.memory.server p2pfl.communication.protocols.protobuff.memory.singleton_dict p2pfl.communication.protocols.protobuff.neighbors p2pfl.communication.protocols.protobuff.proto p2pfl.communication.protocols.protobuff.proto.generate_proto p2pfl.communication.protocols.protobuff.proto.node_pb2 p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc p2pfl.communication.protocols.protobuff.protobuff_communication_protocol p2pfl.communication.protocols.protobuff.server p2pfl.examples p2pfl.exceptions p2pfl.experiment p2pfl.learning p2pfl.learning.aggregators p2pfl.learning.aggregators.aggregator p2pfl.learning.aggregators.fedavg p2pfl.learning.aggregators.fedmedian p2pfl.learning.aggregators.scaffold p2pfl.learning.compression p2pfl.learning.compression.base_compression_strategy p2pfl.learning.compression.lra_strategy p2pfl.learning.compression.lzma_strategy p2pfl.learning.compression.manager p2pfl.learning.compression.quantization_strategy p2pfl.learning.compression.topk_strategy p2pfl.learning.compression.zlib_strategy p2pfl.learning.dataset p2pfl.learning.dataset.p2pfl_dataset p2pfl.learning.dataset.partition_strategies p2pfl.learning.frameworks p2pfl.learning.frameworks.callback p2pfl.learning.frameworks.callback_factory p2pfl.learning.frameworks.exceptions p2pfl.learning.frameworks.flax p2pfl.learning.frameworks.flax.flax_dataset p2pfl.learning.frameworks.flax.flax_learner p2pfl.learning.frameworks.flax.flax_model p2pfl.learning.frameworks.learner p2pfl.learning.frameworks.learner_factory p2pfl.learning.frameworks.p2pfl_model p2pfl.learning.frameworks.pytorch p2pfl.learning.frameworks.pytorch.callbacks p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback p2pfl.learning.frameworks.pytorch.lightning_dataset p2pfl.learning.frameworks.pytorch.lightning_learner p2pfl.learning.frameworks.pytorch.lightning_logger p2pfl.learning.frameworks.pytorch.lightning_model p2pfl.learning.frameworks.simulation p2pfl.learning.frameworks.simulation.actor_pool p2pfl.learning.frameworks.simulation.utils p2pfl.learning.frameworks.simulation.virtual_learner p2pfl.learning.frameworks.tensorflow p2pfl.learning.frameworks.tensorflow.callbacks p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback p2pfl.learning.frameworks.tensorflow.keras_dataset p2pfl.learning.frameworks.tensorflow.keras_learner p2pfl.learning.frameworks.tensorflow.keras_model p2pfl.management p2pfl.management.cli p2pfl.management.launch_from_yaml p2pfl.management.logger p2pfl.management.logger.logger p2pfl.management.message_storage p2pfl.management.metric_storage p2pfl.management.node_monitor p2pfl.management.p2pfl_web_services p2pfl.node p2pfl.node_state p2pfl.settings p2pfl.stages p2pfl.stages.base_node p2pfl.stages.base_node.gossip_model_stage p2pfl.stages.base_node.round_finished_stage p2pfl.stages.base_node.start_learning_stage p2pfl.stages.base_node.train_stage p2pfl.stages.base_node.vote_train_set_stage p2pfl.stages.base_node.wait_agg_models_stage p2pfl.stages.stage p2pfl.stages.stage_factory p2pfl.stages.workflows N name (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger property) name() (p2pfl.stages.base_node.gossip_model_stage.GossipModelStage static method) (p2pfl.stages.base_node.round_finished_stage.RoundFinishedStage static method) (p2pfl.stages.base_node.start_learning_stage.StartLearningStage static method) (p2pfl.stages.base_node.train_stage.TrainStage static method) (p2pfl.stages.base_node.vote_train_set_stage.VoteTrainSetStage static method) (p2pfl.stages.base_node.wait_agg_models_stage.WaitAggregatedModelsStage static method) (p2pfl.stages.stage.Stage static method) nei_status (p2pfl.node_state.NodeState attribute) NeighborNotConnectedError Neighbors (class in p2pfl.communication.protocols.protobuff.neighbors) Node (class in p2pfl.node) NodeMonitor (class in p2pfl.management.node_monitor) NodeNotRegistered NodeRunningException NodeServices (class in p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc) NodeServicesServicer (class in p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc) NodeServicesStub (class in p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc) NodeState (class in p2pfl.node_state) NoModelsToAggregateError num_actors (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) O on_before_zero_grad() (p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback.SCAFFOLDCallback method) on_epoch_end() (p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger.FederatedLogger method) on_train_batch_end() (p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger.FederatedLogger method) (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.SCAFFOLDCallback method) on_train_batch_start() (p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback.SCAFFOLDCallback method) on_train_begin() (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.SCAFFOLDCallback method) on_train_end() (p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback.SCAFFOLDCallback method) (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.SCAFFOLDCallback method) on_train_start() (p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback.SCAFFOLDCallback method) P p2pfl module p2pfl.communication module p2pfl.communication.commands module p2pfl.communication.commands.command module p2pfl.communication.commands.message module p2pfl.communication.commands.message.heartbeat_command module p2pfl.communication.commands.message.metrics_command module p2pfl.communication.commands.message.model_initialized_command module p2pfl.communication.commands.message.models_agregated_command module p2pfl.communication.commands.message.models_ready_command module p2pfl.communication.commands.message.start_learning_command module p2pfl.communication.commands.message.stop_learning_command module p2pfl.communication.commands.message.vote_train_set_command module p2pfl.communication.commands.weights module p2pfl.communication.commands.weights.full_model_command module p2pfl.communication.commands.weights.init_model_command module p2pfl.communication.commands.weights.partial_model_command module p2pfl.communication.protocols module p2pfl.communication.protocols.communication_protocol module p2pfl.communication.protocols.exceptions module p2pfl.communication.protocols.protobuff module p2pfl.communication.protocols.protobuff.client module p2pfl.communication.protocols.protobuff.gossiper module p2pfl.communication.protocols.protobuff.grpc module p2pfl.communication.protocols.protobuff.grpc.address module p2pfl.communication.protocols.protobuff.grpc.client module p2pfl.communication.protocols.protobuff.grpc.server module p2pfl.communication.protocols.protobuff.heartbeater module p2pfl.communication.protocols.protobuff.memory module p2pfl.communication.protocols.protobuff.memory.client module p2pfl.communication.protocols.protobuff.memory.server module p2pfl.communication.protocols.protobuff.memory.singleton_dict module p2pfl.communication.protocols.protobuff.neighbors module p2pfl.communication.protocols.protobuff.proto module p2pfl.communication.protocols.protobuff.proto.generate_proto module p2pfl.communication.protocols.protobuff.proto.node_pb2 module p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc module p2pfl.communication.protocols.protobuff.protobuff_communication_protocol module p2pfl.communication.protocols.protobuff.server module p2pfl.examples module p2pfl.exceptions module p2pfl.experiment module p2pfl.learning module p2pfl.learning.aggregators module p2pfl.learning.aggregators.aggregator module p2pfl.learning.aggregators.fedavg module p2pfl.learning.aggregators.fedmedian module p2pfl.learning.aggregators.scaffold module p2pfl.learning.compression module p2pfl.learning.compression.base_compression_strategy module p2pfl.learning.compression.lra_strategy module p2pfl.learning.compression.lzma_strategy module p2pfl.learning.compression.manager module p2pfl.learning.compression.quantization_strategy module p2pfl.learning.compression.topk_strategy module p2pfl.learning.compression.zlib_strategy module p2pfl.learning.dataset module p2pfl.learning.dataset.p2pfl_dataset module p2pfl.learning.dataset.partition_strategies module p2pfl.learning.frameworks module p2pfl.learning.frameworks.callback module p2pfl.learning.frameworks.callback_factory module p2pfl.learning.frameworks.exceptions module p2pfl.learning.frameworks.flax module p2pfl.learning.frameworks.flax.flax_dataset module p2pfl.learning.frameworks.flax.flax_learner module p2pfl.learning.frameworks.flax.flax_model module p2pfl.learning.frameworks.learner module p2pfl.learning.frameworks.learner_factory module p2pfl.learning.frameworks.p2pfl_model module p2pfl.learning.frameworks.pytorch module p2pfl.learning.frameworks.pytorch.callbacks module p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback module p2pfl.learning.frameworks.pytorch.lightning_dataset module p2pfl.learning.frameworks.pytorch.lightning_learner module p2pfl.learning.frameworks.pytorch.lightning_logger module p2pfl.learning.frameworks.pytorch.lightning_model module p2pfl.learning.frameworks.simulation module p2pfl.learning.frameworks.simulation.actor_pool module p2pfl.learning.frameworks.simulation.utils module p2pfl.learning.frameworks.simulation.virtual_learner module p2pfl.learning.frameworks.tensorflow module p2pfl.learning.frameworks.tensorflow.callbacks module p2pfl.learning.frameworks.tensorflow.callbacks.keras_logger module p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback module p2pfl.learning.frameworks.tensorflow.keras_dataset module p2pfl.learning.frameworks.tensorflow.keras_learner module p2pfl.learning.frameworks.tensorflow.keras_model module p2pfl.management module p2pfl.management.cli module p2pfl.management.launch_from_yaml module p2pfl.management.logger module p2pfl.management.logger.logger module p2pfl.management.message_storage module p2pfl.management.metric_storage module p2pfl.management.node_monitor module p2pfl.management.p2pfl_web_services module p2pfl.node module p2pfl.node_state module p2pfl.settings module p2pfl.stages module p2pfl.stages.base_node module p2pfl.stages.base_node.gossip_model_stage module p2pfl.stages.base_node.round_finished_stage module p2pfl.stages.base_node.start_learning_stage module p2pfl.stages.base_node.train_stage module p2pfl.stages.base_node.vote_train_set_stage module p2pfl.stages.base_node.wait_agg_models_stage module p2pfl.stages.stage module p2pfl.stages.stage_factory module p2pfl.stages.workflows module P2PFLCallback (class in p2pfl.learning.frameworks.callback) P2PFLDataset (class in p2pfl.learning.dataset.p2pfl_dataset) P2PFLModel (class in p2pfl.learning.frameworks.p2pfl_model) P2PFLogger (class in p2pfl.management.logger.logger) P2pflWebServices (class in p2pfl.management.p2pfl_web_services) P2pflWebServicesError PartialModelCommand (class in p2pfl.communication.commands.weights.partial_model_command) path (p2pfl.management.cli.ExampleInfo attribute) PercentageBasedNonIIDPartitionStrategy (class in p2pfl.learning.dataset.partition_strategies) PERIOD (p2pfl.settings.Gossip attribute) (p2pfl.settings.Heartbeat attribute) pool_size_from_resources() (in module p2pfl.learning.frameworks.simulation.utils) process_unordered_future() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) ProtobuffClient (class in p2pfl.communication.protocols.protobuff.client) ProtobuffCommunicationProtocol (class in p2pfl.communication.protocols.protobuff.protobuff_communication_protocol) ProtobuffServer (class in p2pfl.communication.protocols.protobuff.server) ProtocolNotStartedError PTQuantization (class in p2pfl.learning.compression.quantization_strategy) PYTORCH (p2pfl.learning.frameworks.Framework attribute) PyTorchExportStrategy (class in p2pfl.learning.frameworks.pytorch.lightning_dataset) R RandomIIDPartitionStrategy (class in p2pfl.learning.dataset.partition_strategies) refresh_or_add() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) register_callback() (p2pfl.learning.frameworks.callback_factory.CallbackFactory class method) register_node() (p2pfl.management.logger.logger.P2PFLogger method) (p2pfl.management.p2pfl_web_services.P2pflWebServices method) remote() (in module p2pfl.management.cli) remove() (p2pfl.communication.protocols.protobuff.neighbors.Neighbors method) REQUIRED_INFO_KEYS (p2pfl.learning.aggregators.scaffold.Scaffold attribute) RESOURCE_MONITOR_PERIOD (p2pfl.settings.General attribute) resources (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool attribute) reverse() (p2pfl.learning.compression.manager.CompressionManager static method) reverse_strategy() (p2pfl.learning.compression.base_compression_strategy.ByteCompressor method) (p2pfl.learning.compression.base_compression_strategy.CompressionStrategy method) (p2pfl.learning.compression.base_compression_strategy.TensorCompressor method) (p2pfl.learning.compression.lra_strategy.LowRankApproximation method) (p2pfl.learning.compression.lzma_strategy.LZMACompressor method) (p2pfl.learning.compression.quantization_strategy.PTQuantization method) (p2pfl.learning.compression.topk_strategy.TopKSparsification method) (p2pfl.learning.compression.zlib_strategy.ZlibCompressor method) round (p2pfl.experiment.Experiment attribute) (p2pfl.node_state.NodeState property) RoundFinishedStage (class in p2pfl.stages.base_node.round_finished_stage) run() (in module p2pfl.management.cli) (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.communication.protocols.protobuff.heartbeater.Heartbeater method) (p2pfl.management.node_monitor.NodeMonitor method) (p2pfl.stages.workflows.StageWokflow method) run_from_yaml() (in module p2pfl.management.launch_from_yaml) running() (in module p2pfl.communication.protocols.protobuff.protobuff_communication_protocol) S save() (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger method) Scaffold (class in p2pfl.learning.aggregators.scaffold) SCAFFOLDCallback (class in p2pfl.learning.frameworks.pytorch.callbacks.scaffold_callback) (class in p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback) ScaffoldOptimizerWrapper (class in p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback) SEED (p2pfl.settings.General attribute) self() (p2pfl.experiment.Experiment method) send() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.client.ProtobuffClient method) (p2pfl.communication.protocols.protobuff.grpc.client.GrpcClient method) (p2pfl.communication.protocols.protobuff.memory.client.MemoryClient method) (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServices static method) (p2pfl.communication.protocols.protobuff.proto.node_pb2_grpc.NodeServicesServicer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) send_communication_log() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) send_global_metric() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) send_local_metric() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) send_log() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) send_system_metric() (p2pfl.management.p2pfl_web_services.P2pflWebServices method) SERVER_CRT (p2pfl.settings.SSL attribute) SERVER_KEY (p2pfl.settings.SSL attribute) set_additional_info() (p2pfl.learning.frameworks.tensorflow.callbacks.scaffold_callback.SCAFFOLDCallback method) set_addr() (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.communication.protocols.protobuff.grpc.server.GrpcServer method) (p2pfl.communication.protocols.protobuff.heartbeater.Heartbeater method) (p2pfl.communication.protocols.protobuff.memory.server.MemoryServer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.learning.frameworks.pytorch.lightning_learner.LightningLearner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) set_batch_size() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) set_contribution() (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) set_data() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.node.Node method) set_epochs() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) set_experiment() (p2pfl.node_state.NodeState method) set_from_dict() (p2pfl.settings.Settings class method) set_info() (p2pfl.learning.frameworks.callback.P2PFLCallback method) set_learner() (p2pfl.node.Node method) set_level() (p2pfl.management.logger.logger.P2PFLogger method) set_model() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) (p2pfl.learning.frameworks.tensorflow.keras_learner.KerasLearner method) (p2pfl.node.Node method) set_nodes_to_aggregate() (p2pfl.learning.aggregators.aggregator.Aggregator method) set_parameters() (p2pfl.learning.frameworks.flax.flax_model.FlaxModel method) (p2pfl.learning.frameworks.p2pfl_model.P2PFLModel method) (p2pfl.learning.frameworks.pytorch.lightning_model.LightningModel method) (p2pfl.learning.frameworks.tensorflow.keras_model.KerasModel method) set_report_fn() (p2pfl.management.node_monitor.NodeMonitor method) set_start_learning() (p2pfl.node.Node method) set_stop_learning() (p2pfl.node.Node method) set_transforms() (p2pfl.learning.dataset.p2pfl_dataset.P2PFLDataset method) Settings (class in p2pfl.settings) SingletonDict (class in p2pfl.communication.protocols.protobuff.memory.singleton_dict) SSL (class in p2pfl.settings) ssl (p2pfl.settings.Settings attribute) Stage (class in p2pfl.stages.stage) StageFactory (class in p2pfl.stages.stage_factory) StageWokflow (class in p2pfl.stages.workflows) start() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.communication.protocols.protobuff.grpc.server.GrpcServer method) (p2pfl.communication.protocols.protobuff.memory.server.MemoryServer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) (p2pfl.node.Node method) start_thread_lock (p2pfl.node_state.NodeState attribute) StartLearningCommand (class in p2pfl.communication.commands.message.start_learning_command) StartLearningStage (class in p2pfl.stages.base_node.start_learning_stage) status (p2pfl.node_state.NodeState attribute) stop() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.gossiper.Gossiper method) (p2pfl.communication.protocols.protobuff.grpc.server.GrpcServer method) (p2pfl.communication.protocols.protobuff.heartbeater.Heartbeater method) (p2pfl.communication.protocols.protobuff.memory.server.MemoryServer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) (p2pfl.management.node_monitor.NodeMonitor method) (p2pfl.node.Node method) StopLearningCommand (class in p2pfl.communication.commands.message.stop_learning_command) submit() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) submit_learner_job() (p2pfl.learning.frameworks.simulation.actor_pool.SuperActorPool method) SuperActorPool (class in p2pfl.learning.frameworks.simulation.actor_pool) SUPPORTS_PARTIAL_AGGREGATION (p2pfl.learning.aggregators.aggregator.Aggregator attribute) (p2pfl.learning.aggregators.fedavg.FedAvg attribute) (p2pfl.learning.aggregators.fedmedian.FedMedian attribute) (p2pfl.learning.aggregators.scaffold.Scaffold attribute) T TensorCompressor (class in p2pfl.learning.compression.base_compression_strategy) TENSORFLOW (p2pfl.learning.frameworks.Framework attribute) TIMEOUT (p2pfl.settings.Heartbeat attribute) TopKSparsification (class in p2pfl.learning.compression.topk_strategy) TorchvisionDatasetFactory (class in p2pfl.learning.frameworks.pytorch.lightning_dataset) total_rounds (p2pfl.experiment.Experiment attribute) (p2pfl.node_state.NodeState attribute) (p2pfl.node_state.NodeState property) train_set (p2pfl.node_state.NodeState attribute) train_set_votes (p2pfl.node_state.NodeState attribute) train_set_votes_lock (p2pfl.node_state.NodeState attribute) train_step() (p2pfl.learning.frameworks.flax.flax_learner.FlaxLearner method) Training (class in p2pfl.settings) training (p2pfl.settings.Settings attribute) TrainStage (class in p2pfl.stages.base_node.train_stage) try_init_learner_with_ray() (in module p2pfl.learning.frameworks.simulation) TTL (p2pfl.settings.Gossip attribute) U unregister_node() (p2pfl.management.logger.logger.P2PFLogger method) (p2pfl.management.p2pfl_web_services.P2pflWebServices method) update_callbacks_with_model_info() (p2pfl.learning.frameworks.learner.Learner method) (p2pfl.learning.frameworks.simulation.virtual_learner.VirtualNodeLearner method) USE_SSL (p2pfl.settings.SSL attribute) V version (p2pfl.learning.frameworks.pytorch.lightning_logger.FederatedLogger property) VirtualNodeLearner (class in p2pfl.learning.frameworks.simulation.virtual_learner) VOTE_TIMEOUT (p2pfl.settings.Training attribute) VoteTrainSetCommand (class in p2pfl.communication.commands.message.vote_train_set_command) VoteTrainSetStage (class in p2pfl.stages.base_node.vote_train_set_stage) W wait_and_get_aggregation() (p2pfl.learning.aggregators.aggregator.Aggregator method) WAIT_CONVERGENCE (p2pfl.settings.Heartbeat attribute) wait_for_termination() (p2pfl.communication.protocols.communication_protocol.CommunicationProtocol method) (p2pfl.communication.protocols.protobuff.grpc.server.GrpcServer method) (p2pfl.communication.protocols.protobuff.memory.server.MemoryServer method) (p2pfl.communication.protocols.protobuff.protobuff_communication_protocol.ProtobuffCommunicationProtocol method) (p2pfl.communication.protocols.protobuff.server.ProtobuffServer method) wait_votes_ready_lock (p2pfl.node_state.NodeState attribute) WaitAggregatedModelsStage (class in p2pfl.stages.base_node.wait_agg_models_stage) warning() (p2pfl.management.logger.logger.P2PFLogger method) Z ZeroRoundsException ZlibCompressor (class in p2pfl.learning.compression.zlib_strategy)