Selaa lähdekoodia

update comment style for doxygen

Nathalie Furmento 4 vuotta sitten
vanhempi
commit
eef597106c

+ 4 - 4
mpi/src/load_balancer/policy/data_movements_interface.h

@@ -21,14 +21,14 @@
 #ifndef __DATA_MOVEMENTS_INTERFACE_H
 #define __DATA_MOVEMENTS_INTERFACE_H
 
-/* interface for data_movements */
+/** interface for data_movements */
 struct data_movements_interface
 {
-	/* Data tags table */
+	/** Data tags table */
 	int *tags;
-	/* Ranks table (where to move the corresponding data) */
+	/** Ranks table (where to move the corresponding data) */
 	int *ranks;
-	/* Size of the tables */
+	/** Size of the tables */
 	int size;
 };
 

+ 2 - 2
mpi/src/load_balancer/policy/load_balancer_policy.h

@@ -26,7 +26,7 @@ extern "C"
 {
 #endif
 
-/* A load balancer consists in a collection of operations on a data
+/** A load balancer consists in a collection of operations on a data
  * representing the load of the application (in terms of computation, memory,
  * whatever). StarPU allows several entry points for the user. The load
  * balancer allows the user to give its load balancing methods to be used on
@@ -38,7 +38,7 @@ struct load_balancer_policy
 	void (*submitted_task_entry_point)();
 	void (*finished_task_entry_point)();
 
-	/* Name of the load balancing policy. The selection of the load balancer is
+	/** Name of the load balancing policy. The selection of the load balancer is
 	 * performed through the use of the STARPU_MPI_LB=name environment
 	 * variable.
 	 */

+ 9 - 9
mpi/src/load_balancer/policy/load_data_interface.h

@@ -21,26 +21,26 @@
 #ifndef __LOAD_DATA_INTERFACE_H
 #define __LOAD_DATA_INTERFACE_H
 
-/* interface for load_data */
+/** interface for load_data */
 struct load_data_interface
 {
-	/* Starting time of the execution */
+	/** Starting time of the execution */
 	double start;
-	/* Elapsed time until the start time and the time when event "launch a load
+	/** Elapsed time until the start time and the time when event "launch a load
 	 * balancing phase" is triggered */
 	double elapsed_time;
-	/* Current submission phase, i.e how many balanced steps have already
+	/** Current submission phase, i.e how many balanced steps have already
 	 * happened so far. */
 	int phase;
-	/* Number of currently submitted tasks */
+	/** Number of currently submitted tasks */
 	int nsubmitted_tasks;
-	/* Number of currently finished tasks */
+	/** Number of currently finished tasks */
 	int nfinished_tasks;
-	/* Task threshold to sleep the submission thread */
+	/** Task threshold to sleep the submission thread */
 	int sleep_task_threshold;
-	/* Task threshold to wake-up the submission thread */
+	/** Task threshold to wake-up the submission thread */
 	int wakeup_task_threshold;
-	/* Ratio of submitted tasks to wait for completion before waking up the
+	/** Ratio of submitted tasks to wait for completion before waking up the
 	 * submission thread */
 	double wakeup_ratio;
 };

+ 1 - 1
mpi/src/mpi/starpu_mpi_mpi_backend.h

@@ -56,7 +56,7 @@ struct _starpu_mpi_req_backend
 	starpu_pthread_cond_t req_cond;
 	starpu_pthread_mutex_t posted_mutex;
 	starpu_pthread_cond_t posted_cond;
-	/* In the case of a Wait/Test request, we are going to post a request
+	/** In the case of a Wait/Test request, we are going to post a request
 	 * to test the completion of another request */
 	struct _starpu_mpi_req *other_request;
 

+ 1 - 1
mpi/src/nmad/starpu_mpi_nmad_backend.h

@@ -40,7 +40,7 @@ struct _starpu_mpi_req_backend
 	piom_cond_t req_cond;
 	nm_sr_request_t size_req;
 
-	// When datatype is unknown:
+	/** When datatype is unknown */
 	struct nm_data_s unknown_datatype_body;
 	struct nm_data_s unknown_datatype_data;
 	struct nm_data_s unknown_datatype_size;

+ 6 - 3
mpi/src/starpu_mpi_private.h

@@ -248,7 +248,8 @@ LIST_TYPE(_starpu_mpi_req,
 
 	int ret;
 
-	enum _starpu_mpi_request_type request_type; /* 0 send, 1 recv */
+	/** 0 send, 1 recv */
+	enum _starpu_mpi_request_type request_type;
 
 	unsigned submitted;
 	unsigned completed;
@@ -317,8 +318,10 @@ struct _starpu_mpi_argc_argv
 	int *argc;
 	char ***argv;
 	MPI_Comm comm;
-	int fargc;	// Fortran argc
-	char **fargv;	// Fortran argv
+	/** Fortran argc */
+	int fargc;
+	/** Fortran argv */
+	char **fargv;
 	int rank;
 	int world_size;
 };

+ 1 - 1
src/common/fxt.h

@@ -290,7 +290,7 @@ extern int _starpu_fxt_willstart;
 extern starpu_pthread_mutex_t _starpu_fxt_started_mutex;
 extern starpu_pthread_cond_t _starpu_fxt_started_cond;
 
-/* Wait until FXT is started (or not). Returns if FXT was started */
+/** Wait until FXT is started (or not). Returns if FXT was started */
 static inline int _starpu_fxt_wait_initialisation()
 {
 	STARPU_PTHREAD_MUTEX_LOCK(&_starpu_fxt_started_mutex);

+ 29 - 14
src/common/graph.h

@@ -28,8 +28,10 @@ MULTILIST_CREATE_TYPE(_starpu_graph_node, dropped)
 
 struct _starpu_graph_node
 {
-	starpu_pthread_mutex_t mutex;	/* protects access to the job */
-	struct _starpu_job *job;	/* pointer to the job, if it is still alive, NULL otherwise */
+	/** protects access to the job */
+	starpu_pthread_mutex_t mutex;
+	/** pointer to the job, if it is still alive, NULL otherwise */
+	struct _starpu_job *job;
 
 	/**
 	 * Fields for graph analysis for scheduling heuristics
@@ -44,22 +46,35 @@ struct _starpu_graph_node
 	struct _starpu_graph_node_multilist_dropped dropped;
 
 	/** set of incoming dependencies */
-	struct _starpu_graph_node **incoming;	/* May contain NULLs for terminated jobs */
-	unsigned *incoming_slot;	/* Index within corresponding outgoing array */
-	unsigned n_incoming;		/* Number of slots used */
-	unsigned alloc_incoming;	/* Size of incoming */
+	/** May contain NULLs for terminated jobs */
+	struct _starpu_graph_node **incoming;
+	/** Index within corresponding outgoing array */
+	unsigned *incoming_slot;
+	/** Number of slots used */
+	unsigned n_incoming;
+	/** Size of incoming */
+	unsigned alloc_incoming;
 	/** set of outgoing dependencies */
 	struct _starpu_graph_node **outgoing;
-	unsigned *outgoing_slot;	/* Index within corresponding incoming array */
-	unsigned n_outgoing;		/* Number of slots used */
-	unsigned alloc_outgoing;	/* Size of outgoing */
 
-	unsigned depth;			/* Rank from bottom, in number of jobs */
-					/* Only available if _starpu_graph_compute_depths was called */
-	unsigned descendants;		/* Number of children, grand-children, etc. */
-					/* Only available if _starpu_graph_compute_descendants was called */
+	/** Index within corresponding incoming array */
+	unsigned *outgoing_slot;
+	/** Number of slots used */
+	unsigned n_outgoing;
+	/** Size of outgoing */
+	unsigned alloc_outgoing;
 
-	int graph_n;			/* Variable available for graph flow */
+	/** Rank from bottom, in number of jobs
+	 * Only available if _starpu_graph_compute_depths was called
+	 */
+	unsigned depth;
+	/** Number of children, grand-children, etc.
+	 * Only available if _starpu_graph_compute_descendants was called
+	 */
+	unsigned descendants;
+
+	/** Variable available for graph flow */
+	int graph_n;
 };
 
 MULTILIST_CREATE_INLINES(struct _starpu_graph_node, _starpu_graph_node, all)

+ 4 - 6
src/common/knobs.h

@@ -96,7 +96,7 @@ __STARPU_PERF_COUNTER_UPDATE_64BIT(min,<=,double,double);
 #undef __STARPU_PERF_COUNTER_UPDATE_32BIT
 #undef __STARPU_PERF_COUNTER_UPDATE_64BIT
 
-/* Floating point atomic accumulate */
+/** Floating point atomic accumulate */
 static inline void _starpu_perf_counter_update_acc_float(float *ptr, float acc_value)
 {
 	STARPU_ASSERT(sizeof(float) == sizeof(uint32_t));
@@ -339,14 +339,12 @@ static inline int _starpu_perf_knob_id_build(const enum starpu_perf_knob_scope s
 	return (index << _STARPU_PERF_KNOBS_ID_SCOPE_BITS) | scope;
 }
 
-
 void _starpu_perf_knob_init(void);
 void _starpu_perf_knob_exit(void);
 
-struct starpu_perf_knob_group *_starpu_perf_knob_group_register(
-	enum starpu_perf_knob_scope scope,
-	void (*set_func)(const struct starpu_perf_knob * const knob, void *context, const struct starpu_perf_knob_value * const value),
-	void (*get_func)(const struct starpu_perf_knob * const knob, void *context,       struct starpu_perf_knob_value * const value));
+struct starpu_perf_knob_group *_starpu_perf_knob_group_register(enum starpu_perf_knob_scope scope,
+								void (*set_func)(const struct starpu_perf_knob * const knob, void *context, const struct starpu_perf_knob_value * const value),
+								void (*get_func)(const struct starpu_perf_knob * const knob, void *context, struct starpu_perf_knob_value * const value));
 void _starpu_perf_knob_group_unregister(struct starpu_perf_knob_group *group);
 
 int _starpu_perf_knob_register(struct starpu_perf_knob_group *group, const char *name, enum starpu_perf_knob_type type, const char *help);

+ 4 - 5
src/common/timing.h

@@ -19,11 +19,6 @@
 
 /** @file */
 
-/*
- * _starpu_timing_init must be called prior to using any of these timing
- * functions.
- */
-
 #include <stdint.h>
 #include <common/config.h>
 #ifdef HAVE_UNISTD_H
@@ -32,6 +27,10 @@
 #include <starpu.h>
 #include <starpu_util.h>
 
+/**
+ * _starpu_timing_init must be called prior to using any of these timing
+ * functions.
+ */
 void _starpu_timing_init(void);
 void _starpu_clock_gettime(struct timespec *ts);
 

+ 1 - 1
src/common/utils.h

@@ -152,7 +152,7 @@ char *_starpu_mkdtemp(char *tmpl);
 int _starpu_mkpath(const char *s, mode_t mode);
 void _starpu_mkpath_and_check(const char *s, mode_t mode);
 char *_starpu_mktemp(const char *directory, int flags, int *fd);
-/* This version creates a hierarchy of n temporary directories, useful when
+/** This version creates a hierarchy of n temporary directories, useful when
  * creating a lot of temporary files to be stored in the same place */
 char *_starpu_mktemp_many(const char *directory, int depth, int flags, int *fd);
 void _starpu_rmtemp_many(char *path, int depth);

+ 5 - 5
src/core/debug.h

@@ -290,20 +290,20 @@
 
 #endif
 
-/* Create a file that will contain StarPU's log */
+/** Create a file that will contain StarPU's log */
 void _starpu_open_debug_logfile(void);
 
-/* Close StarPU's log file */
+/** Close StarPU's log file */
 void _starpu_close_debug_logfile(void);
 
-/* Write into StarPU's log file */
+/** Write into StarPU's log file */
 void _starpu_print_to_logfile(const char *format, ...) STARPU_ATTRIBUTE_FORMAT(printf, 1, 2);
 
-/* Tell gdb whether FXT is compiled in or not */
+/** Tell gdb whether FXT is compiled in or not */
 extern int _starpu_use_fxt;
 
 #if defined(STARPU_USE_AYUDAME1)
-/* Get an Ayudame id for CL */
+/** Get an Ayudame id for CL */
 int64_t _starpu_ayudame_get_func_id(struct starpu_codelet *cl);
 #endif
 

+ 14 - 9
src/core/dependencies/cg.h

@@ -60,7 +60,8 @@ struct _starpu_cg_list
 	/** List of successors */
 	unsigned nsuccs; /* how many successors ? */
 #ifdef STARPU_DYNAMIC_DEPS_SIZE
-	unsigned succ_list_size; /* How many allocated items in succ */
+	/** How many allocated items in succ */
+	unsigned succ_list_size;
 	struct _starpu_cg **succ;
 #else
 	struct _starpu_cg *succ[STARPU_NMAXDEPS];
@@ -77,27 +78,31 @@ enum _starpu_cg_type
 /** Completion Group */
 struct _starpu_cg
 {
-	unsigned ntags; /* number of tags depended on */
-	unsigned remaining; /* number of remaining tags */
+	/** number of tags depended on */
+	unsigned ntags;
+	/** number of remaining tags */
+	unsigned remaining;
 
 #ifdef STARPU_DEBUG
 	unsigned ndeps;
-	void **deps; /* array of predecessors, size ndeps */
-	char *done;  /* which ones have notified, size ndeps */
+	/** array of predecessors, size ndeps */
+	void **deps;
+	/** which ones have notified, size ndeps */
+	char *done;
 #endif
 
 	enum _starpu_cg_type cg_type;
 
 	union
 	{
-		/* STARPU_CG_TAG */
+		/** STARPU_CG_TAG */
 		struct _starpu_tag *tag;
 
-		/* STARPU_CG_TASK */
+		/** STARPU_CG_TASK */
 		struct _starpu_job *job;
 
-		/* STARPU_CG_APPS */
-		/* in case this completion group is related to an application,
+		/** STARPU_CG_APPS
+		 * in case this completion group is related to an application,
 		 * we have to explicitely wake the waiting thread instead of
 		 * reschedule the corresponding task */
 		struct

+ 14 - 12
src/core/dependencies/tags.h

@@ -28,19 +28,18 @@
 
 enum _starpu_tag_state
 {
-	/* this tag is not declared by any task */
+	/** this tag is not declared by any task */
 	STARPU_INVALID_STATE,
-	/* _starpu_tag_declare was called to associate the tag to a task */
+	/** _starpu_tag_declare was called to associate the tag to a task */
 	STARPU_ASSOCIATED,
-	/* some task dependencies are not fulfilled yet */
+	/** some task dependencies are not fulfilled yet */
 	STARPU_BLOCKED,
-	/* the task can be (or has been) submitted to the scheduler (all deps
- 	 * fulfilled) */
+	/** the task can be (or has been) submitted to the scheduler (all deps fulfilled) */
 	STARPU_READY,
 // useless ...
-//	/* the task has been submitted to the scheduler */
+//	/** the task has been submitted to the scheduler */
 //	STARPU_SCHEDULED,
-	/* the task has been performed */
+	/** the task has been performed */
 	STARPU_DONE
 };
 
@@ -48,15 +47,18 @@ struct _starpu_job;
 
 struct _starpu_tag
 {
-	/* Lock for this structure. Locking order is in dependency order: a tag
-	 * must not be locked before locking a tag it depends on */
+	/**
+	   Lock for this structure. Locking order is in dependency order: a tag
+	   * must not be locked before locking a tag it depends on */
 	struct _starpu_spinlock lock;
-	starpu_tag_t id; /* an identifier for the task */
+	/** an identifier for the task */
+	starpu_tag_t id;
 	enum _starpu_tag_state state;
 
 	struct _starpu_cg_list tag_successors;
 
-	struct _starpu_job *job; /* which job is associated to the tag if any ? */
+	/** which job is associated to the tag if any ? */
+	struct _starpu_job *job;
 
 	unsigned is_assigned;
 	unsigned is_submitted;
@@ -69,7 +71,7 @@ void _starpu_notify_job_start_tag_dependencies(struct _starpu_tag *tag, _starpu_
 
 void _starpu_tag_declare(starpu_tag_t id, struct _starpu_job *job);
 
-/* lock should be taken, and this releases it */
+/** lock should be taken, and this releases it */
 void _starpu_tag_set_ready(struct _starpu_tag *tag);
 
 unsigned _starpu_submit_job_enforce_task_deps(struct _starpu_job *j);

+ 4 - 2
src/core/perfmodel/perfmodel.h

@@ -50,8 +50,10 @@ struct _starpu_perfmodel_state
 	starpu_pthread_rwlock_t model_rwlock;
 	int *nimpls;
 	int *nimpls_set;
-	int ncombs;  /* The number of combinations currently used by the model */
-	int ncombs_set; /* The number of combinations allocated in the array nimpls and ncombs */
+	/** The number of combinations currently used by the model */
+	int ncombs;
+	/** The number of combinations allocated in the array nimpls and ncombs */
+	int ncombs_set;
 	int *combs;
 };
 

+ 1 - 1
src/core/simgrid.h

@@ -73,7 +73,7 @@ union _starpu_async_channel_event;
 int _starpu_simgrid_wait_transfer_event(union _starpu_async_channel_event *event);
 int _starpu_simgrid_test_transfer_event(union _starpu_async_channel_event *event);
 void _starpu_simgrid_sync_gpus(void);
-/* Return the number of hosts prefixed by PREFIX */
+/** Return the number of hosts prefixed by PREFIX */
 int _starpu_simgrid_get_nbhosts(const char *prefix);
 unsigned long long _starpu_simgrid_get_memsize(const char *prefix, unsigned devid);
 starpu_sg_host_t _starpu_simgrid_get_host_by_name(const char *name);

+ 6 - 3
src/core/topology.h

@@ -31,9 +31,12 @@ struct _starpu_machine_config;
 /** This is allocated for each hwloc object */
 struct _starpu_hwloc_userdata
 {
-	struct _starpu_worker_list *worker_list; /** List of workers running on this obj */
-	unsigned ngpus; /** Number of GPUs sharing this PCI link */
-	struct _starpu_worker *pu_worker; /** Worker running this PU */
+	 /** List of workers running on this obj */
+	struct _starpu_worker_list *worker_list;
+	 /** Number of GPUs sharing this PCI link */
+	unsigned ngpus;
+	/** Worker running this PU */
+	struct _starpu_worker *pu_worker;
 };
 #endif
 #endif

+ 6 - 6
src/core/workers.h

@@ -204,7 +204,7 @@ LIST_TYPE(_starpu_worker,
 	int enable_knob;
 	int bindid_requested;
 
-	/* Keep this last, to make sure to separate worker data in separate
+	  /** Keep this last, to make sure to separate worker data in separate
 	  cache lines. */
 	char padding[STARPU_CACHELINE_SIZE];
 );
@@ -228,7 +228,7 @@ struct _starpu_combined_worker
 	hwloc_bitmap_t hwloc_cpu_set;
 #endif
 
-	/* Keep this last, to make sure to separate worker data in separate
+	/** Keep this last, to make sure to separate worker data in separate
 	  cache lines. */
 	char padding[STARPU_CACHELINE_SIZE];
 };
@@ -397,7 +397,7 @@ struct _starpu_machine_config
 	/** Memory node for MPI, if only one */
 	int mpi_nodeid;
 
-	/* Separate out previous variables from per-worker data. */
+	/** Separate out previous variables from per-worker data. */
 	char padding1[STARPU_CACHELINE_SIZE];
 
 	/** Basic workers : each of this worker is running its own driver and
@@ -410,7 +410,7 @@ struct _starpu_machine_config
 
 	starpu_pthread_mutex_t submitted_mutex;
 
-	/* Separate out previous mutex from the rest of the data. */
+	/** Separate out previous mutex from the rest of the data. */
 	char padding2[STARPU_CACHELINE_SIZE];
 
 	/** Translation table from bindid to worker IDs */
@@ -1201,8 +1201,8 @@ void _starpu_worker_refuse_task(struct _starpu_worker *worker, struct starpu_tas
 void _starpu_set_catch_signals(int do_catch_signal);
 int _starpu_get_catch_signals(void);
 
-/* Performance Monitoring */
-static inline int _starpu_perf_counter_paused(void) 
+/** Performance Monitoring */
+static inline int _starpu_perf_counter_paused(void)
 {
 	STARPU_RMB();
 	return STARPU_UNLIKELY(_starpu_config.perf_counter_pause_depth > 0);

+ 8 - 4
src/datawizard/copy_driver.h

@@ -49,10 +49,14 @@ struct _starpu_data_replicate;
 
 enum _starpu_is_prefetch
 {
-	STARPU_FETCH = 0,		/* A task really needs it now! */
-	STARPU_TASK_PREFETCH = 1,	/* A task will need it soon */
-	STARPU_PREFETCH = 2,		/* It is a good idea to have it asap */
-	STARPU_IDLEFETCH = 3,		/* Get this here when you have time to */
+ 	/** A task really needs it now! */
+ 	STARPU_FETCH = 0,
+	/** A task will need it soon */
+	STARPU_TASK_PREFETCH = 1,
+	/** It is a good idea to have it asap */
+	STARPU_PREFETCH = 2,
+	/** Get this here when you have time to */
+	STARPU_IDLEFETCH = 3,
 	STARPU_NFETCH
 };
 

+ 2 - 1
src/datawizard/data_request.h

@@ -35,7 +35,8 @@
 #define MAX_PENDING_REQUESTS_PER_NODE 20
 #define MAX_PENDING_PREFETCH_REQUESTS_PER_NODE 10
 #define MAX_PENDING_IDLE_REQUESTS_PER_NODE 1
-#define MAX_PUSH_TIME 1000 /* Maximum time in us that we can afford pushing requests before going back to the driver loop, e.g. for checking GPU task termination */
+/** Maximum time in us that we can afford pushing requests before going back to the driver loop, e.g. for checking GPU task termination */
+#define MAX_PUSH_TIME 1000
 
 struct _starpu_data_replicate;
 

+ 2 - 2
src/datawizard/memalloc.h

@@ -59,8 +59,8 @@ LIST_TYPE(_starpu_mem_chunk,
 	unsigned home:1;
 	/** Whether the memchunk is in the clean part of the mc_list */
 	unsigned clean:1;
-	/** Was this chunk used since it got allocated?  */
-	/* FIXME: probably useless now with nb_tasks_prefetch */
+	/** Was this chunk used since it got allocated?
+	    FIXME: probably useless now with nb_tasks_prefetch */
 	unsigned diduse:1;
 	/** Was this chunk marked as "won't use"? */
 	unsigned wontuse:1;

+ 3 - 3
src/datawizard/memory_nodes.h

@@ -45,7 +45,7 @@ struct _starpu_memory_node_descr
 	enum starpu_node_kind nodes[STARPU_MAXNODES];
 	struct _starpu_node_ops *node_ops[STARPU_MAXNODES];
 
-	/* Get the device id associated to this node, or -1 if not applicable */
+	/** Get the device id associated to this node, or -1 if not applicable */
 	int devid[STARPU_MAXNODES];
 
 	unsigned nworkers[STARPU_MAXNODES];
@@ -55,7 +55,7 @@ struct _starpu_memory_node_descr
 #endif
 
 	// TODO move this 2 lists outside struct _starpu_memory_node_descr
-	/* Every worker is associated to a condition variable on which the
+	/** Every worker is associated to a condition variable on which the
 	 * worker waits when there is task available. It is possible that
 	 * multiple worker share the same condition variable, so we maintain a
 	 * list of all these condition variables so that we can wake up all
@@ -63,7 +63,7 @@ struct _starpu_memory_node_descr
 	starpu_pthread_rwlock_t conditions_rwlock;
 	struct _starpu_cond_and_worker conditions_attached_to_node[STARPU_MAXNODES][STARPU_NMAXWORKERS];
 	struct _starpu_cond_and_worker conditions_all[STARPU_MAXNODES*STARPU_NMAXWORKERS];
-	/* the number of queues attached to each node */
+	/** the number of queues attached to each node */
 	unsigned total_condition_count;
 	unsigned condition_count[STARPU_MAXNODES];
 };

+ 1 - 1
src/datawizard/memstats.h

@@ -25,7 +25,7 @@
 #ifdef STARPU_MEMORY_STATS
 struct _starpu_memory_stats
 {
-	/* Handle access stats per node */
+	/** Handle access stats per node */
 	unsigned direct_access[STARPU_MAXNODES];
 	unsigned loaded_shared[STARPU_MAXNODES];
 	unsigned loaded_owner[STARPU_MAXNODES];

+ 1 - 1
src/drivers/mic/driver_mic_source.h

@@ -34,7 +34,7 @@
 
 extern struct _starpu_node_ops _starpu_driver_mic_node_ops;
 
-/* Array of structures containing all the informations useful to send
+/** Array of structures containing all the informations useful to send
  * and receive informations with devices */
 extern struct _starpu_mp_node *_starpu_mic_nodes[STARPU_MAXMICDEVS];
 

+ 2 - 2
src/drivers/mp_common/mp_common.h

@@ -57,12 +57,12 @@ enum _starpu_mp_command
 	STARPU_MP_COMMAND_ANSWER_ALLOCATE,
 	STARPU_MP_COMMAND_ERROR_ALLOCATE,
 	STARPU_MP_COMMAND_FREE,
-        /* Synchronous send */
+        /** Synchronous send */
 	STARPU_MP_COMMAND_RECV_FROM_HOST,
 	STARPU_MP_COMMAND_SEND_TO_HOST,
 	STARPU_MP_COMMAND_RECV_FROM_SINK,
 	STARPU_MP_COMMAND_SEND_TO_SINK,
-        /* Asynchronous send */
+        /** Asynchronous send */
         STARPU_MP_COMMAND_RECV_FROM_HOST_ASYNC,
         STARPU_MP_COMMAND_RECV_FROM_HOST_ASYNC_COMPLETED,
 	STARPU_MP_COMMAND_SEND_TO_HOST_ASYNC,

+ 1 - 1
src/sched_policies/helper_mct.h

@@ -23,7 +23,7 @@ struct _starpu_mct_data
 	double beta;
 	double _gamma;
 	double idle_power;
-	starpu_pthread_mutex_t scheduling_mutex; 
+	starpu_pthread_mutex_t scheduling_mutex;
 };
 
 struct _starpu_mct_data *starpu_mct_init_parameters(struct starpu_sched_component_mct_data *params);

+ 1 - 1
src/sched_policies/prio_deque.h

@@ -27,7 +27,7 @@ struct _starpu_prio_deque
 	struct starpu_task_prio_list list;
 	unsigned ntasks;
 	unsigned nprocessed;
-	// Assumptions: 
+	// Assumptions:
 	// exp_len is the sum of predicted_length + predicted_tansfer of all tasks in list
 	// exp_start is the time at which the first task of list can start
 	// exp_end = exp_start + exp_end

+ 1 - 1
src/sched_policies/sched_component.h

@@ -23,7 +23,7 @@
 #include <starpu_sched_component.h>
 
 
-/* lock and unlock drivers for modifying schedulers */
+/** lock and unlock drivers for modifying schedulers */
 void _starpu_sched_component_lock_all_workers(void);
 void _starpu_sched_component_unlock_all_workers(void);
 

+ 5 - 5
src/util/starpu_clusters_create.h

@@ -79,7 +79,7 @@ LIST_TYPE(_starpu_cluster,
 )
 
 
-/* Machine discovery and cluster creation main funcitons */
+/** Machine discovery and cluster creation main funcitons */
 int _starpu_cluster_machine(hwloc_obj_type_t cluster_level,
 			     struct starpu_cluster_machine* machine);
 int _starpu_cluster_topology(hwloc_obj_type_t cluster_level,
@@ -88,13 +88,13 @@ void _starpu_cluster_group(hwloc_obj_type_t cluster_level,
 			   struct starpu_cluster_machine* machine);
 void _starpu_cluster(struct _starpu_cluster_group* group);
 
-/* Parameter functions */
+/** Parameter functions */
 void _starpu_cluster_init_parameters(struct _starpu_cluster_parameters* globals);
 void _starpu_cluster_copy_parameters(struct _starpu_cluster_parameters* src,
 				     struct _starpu_cluster_parameters* dst);
 int _starpu_cluster_analyze_parameters(struct _starpu_cluster_parameters* params, int npus);
 
-/* Cluster helper functions */
+/** Cluster helper functions */
 void _starpu_cluster_init(struct _starpu_cluster* cluster, struct _starpu_cluster_group* father);
 void _starpu_cluster_create(struct _starpu_cluster* cluster);
 
@@ -102,14 +102,14 @@ int _starpu_cluster_bind(struct _starpu_cluster* cluster);
 int _starpu_cluster_remove(struct _starpu_cluster_list* cluster_list,
 			   struct _starpu_cluster* cluster);
 
-/* Cluster group helper function */
+/** Cluster group helper function */
 void _starpu_cluster_group_init(struct _starpu_cluster_group* group,
 				struct starpu_cluster_machine* father);
 void _starpu_cluster_group_create(struct _starpu_cluster_group* group);
 int _starpu_cluster_group_remove(struct _starpu_cluster_group_list* group_list,
 				 struct _starpu_cluster_group* group);
 
-/* Binding helpers */
+/** Binding helpers */
 void _starpu_cluster_noop(void* buffers[], void* cl_arg)
 {
 	(void) buffers;

+ 25 - 25
starpurm/src/starpurm_private.h

@@ -36,86 +36,86 @@ enum e_starpurm_unit_type
 
 struct s_starpurm
 {
-	/* Machine topology as detected by hwloc. */
+	/** Machine topology as detected by hwloc. */
 	hwloc_topology_t topology;
 
-	/* Current upper bound on the number of CPU cores selectable for computing with the runtime system. */
+	/** Current upper bound on the number of CPU cores selectable for computing with the runtime system. */
 	unsigned max_ncpus;
 
-	/* Number of currently selected CPU workers */
+	/** Number of currently selected CPU workers */
 	unsigned selected_ncpus;
 
-	/* Number of currently selected workers (CPU+devices) */
+	/** Number of currently selected workers (CPU+devices) */
 	unsigned selected_nworkers;
 
-	/* Initialization state of the RM instance. */
+	/** Initialization state of the RM instance. */
 	int state;
 
-	/* Boolean indicating the state of the dynamic resource sharing layer.
+	/** Boolean indicating the state of the dynamic resource sharing layer.
 	 *
 	 * !0 indicates that dynamic resource sharing is enabled.
 	 * 0 indicates that dynamic resource sharing is disabled.
 	 */
 	int dynamic_resource_sharing;
 
-	/* Id of the StarPU's sched_ctx used by the RM instance. */
+	/** Id of the StarPU's sched_ctx used by the RM instance. */
 	unsigned sched_ctx_id;
 
-	/* Number of unit types supported by this RM instance. */
+	/** Number of unit types supported by this RM instance. */
 	int unit_ntypes;
 
-	/* Number of unitss available for each type. */
+	/** Number of unitss available for each type. */
 	int *nunits_by_type;
 
-	/* Number of units. */
+	/** Number of units. */
 	int nunits;
 
-	/* Offset of unit numbering for each type. */
+	/** Offset of unit numbering for each type. */
 	int *unit_offsets_by_type;
 
-	/* Array of units. */
+	/** Array of units. */
 	struct s_starpurm_unit *units;
 
-	/* Cpuset of all the StarPU's workers (CPU+devices. */
+	/** Cpuset of all the StarPU's workers (CPU+devices. */
 	hwloc_cpuset_t global_cpuset;
 
-	/* Cpuset of all StarPU CPU workers. */
+	/** Cpuset of all StarPU CPU workers. */
 	hwloc_cpuset_t all_cpu_workers_cpuset;
 
-	/* Cpuset of all StarPU OpenCL workers. */
+	/** Cpuset of all StarPU OpenCL workers. */
 	hwloc_cpuset_t all_opencl_device_workers_cpuset;
 
-	/* Cpuset of all StarPU CUDA workers. */
+	/** Cpuset of all StarPU CUDA workers. */
 	hwloc_cpuset_t all_cuda_device_workers_cpuset;
 
-	/* Cpuset of all StarPU MIC workers. */
+	/** Cpuset of all StarPU MIC workers. */
 	hwloc_cpuset_t all_mic_device_workers_cpuset;
 
-	/* Cpuset of all StarPU device workers. */
+	/** Cpuset of all StarPU device workers. */
 	hwloc_cpuset_t all_device_workers_cpuset;
 
-	/* Cpuset of all selected workers (CPU+devices). */
+	/** Cpuset of all selected workers (CPU+devices). */
 	hwloc_cpuset_t selected_cpuset;
 
-	/* Cpuset mask of initially owned cpuset or full if not used. */
+	/** Cpuset mask of initially owned cpuset or full if not used. */
 	hwloc_cpuset_t initially_owned_cpuset_mask;
 
-	/* maximum value among worker ids */
+	/** maximum value among worker ids */
 	int max_worker_id;
 
-	/* worker id to unit id table */
+	/** worker id to unit id table */
 	int *worker_unit_ids;
 
-	/* Temporary contexts accounting. */
+	/** Temporary contexts accounting. */
 	unsigned int max_temporary_ctxs;
 	unsigned int avail_temporary_ctxs;
 	pthread_mutex_t temporary_ctxs_mutex;
 	pthread_cond_t temporary_ctxs_cond;
 
-	/* Global StarPU pause state */
+	/** Global StarPU pause state */
 	int starpu_in_pause;
 
-	/* Event list. */
+	/** Event list. */
 	pthread_t event_thread;
 	pthread_mutex_t event_list_mutex;
 	pthread_cond_t event_list_cond;