Logo AND Algorithmique Numérique Distribuée

Public GIT Repository
This change concerne the usage of the semaphore object instead the variable condition...
[simgrid.git] / src / xbt / xbt_os_thread.c
index 91b38fe..0405622 100644 (file)
 
 #include "xbt/sysdep.h"
 #include "xbt/ex.h"
+#include "xbt/ex_interface.h" /* We play crude games with exceptions */
 #include "portable.h"
+#include "xbt/xbt_os_time.h" /* Portable time facilities */
 #include "xbt/xbt_os_thread.h" /* This module */
 #include "xbt_modinter.h" /* Initialization/finalization of this module */
 
-
+XBT_LOG_NEW_DEFAULT_SUBCATEGORY(xbt_sync_os,xbt,"Synchronization mechanism (OS-level)");
 
 /* ********************************* PTHREAD IMPLEMENTATION ************************************ */
 #ifdef HAVE_PTHREAD_H
 #include <pthread.h>
+#include <semaphore.h>
 
 typedef struct xbt_os_thread_ {
    pthread_t t;
+   char *name;
    void *param;
-   pvoid_f_pvoid_t *start_routine;
+   pvoid_f_pvoid_t start_routine;
+   ex_ctx_t *exception;
 } s_xbt_os_thread_t ;
+static xbt_os_thread_t main_thread = NULL;
 
 /* thread-specific data containing the xbt_os_thread_t structure */
 static pthread_key_t xbt_self_thread_key;
+static int thread_mod_inited = 0;
 
 /* frees the xbt_os_thread_t corresponding to the current thread */
 static void xbt_os_thread_free_thread_data(void*d){
    free(d);
 }
 
+/* callback: context fetching */
+static ex_ctx_t *_os_thread_ex_ctx(void) {
+  return xbt_os_thread_self()->exception;
+}
+
+/* callback: termination */
+static void _os_thread_ex_terminate(xbt_ex_t * e) {
+  xbt_ex_display(e);
+
+  abort();
+  /* FIXME: there should be a configuration variable to choose to kill everyone or only this one */
+}
+
 void xbt_os_thread_mod_init(void) {
    int errcode;
    
+   if (thread_mod_inited)
+     return;
+   
    if ((errcode=pthread_key_create(&xbt_self_thread_key, NULL)))
      THROW0(system_error,errcode,"pthread_key_create failed for xbt_self_thread_key");
+
+   main_thread=xbt_new(s_xbt_os_thread_t,1);
+   main_thread->name = (char*)"main";
+   main_thread->start_routine = NULL;
+   main_thread->param = NULL;
+   main_thread->exception = xbt_new(ex_ctx_t, 1);
+   XBT_CTX_INITIALIZE(main_thread->exception);
+
+   __xbt_ex_ctx = _os_thread_ex_ctx;
+   __xbt_ex_terminate = _os_thread_ex_terminate;
+
+   thread_mod_inited = 1;
 }
 void xbt_os_thread_mod_exit(void) {
-   /* FIXME: don't try to free our key on shutdown. Valgrind detects no leak if we don't, and whine if we try to */
+   /* FIXME: don't try to free our key on shutdown. 
+      Valgrind detects no leak if we don't, and whine if we try to */
 //   int errcode;
    
 //   if ((errcode=pthread_key_delete(xbt_self_thread_key)))
@@ -55,34 +91,54 @@ static void * wrapper_start_routine(void *s) {
   int errcode;
 
   if ((errcode=pthread_setspecific(xbt_self_thread_key,t)))
-    THROW0(system_error,errcode,"pthread_setspecific failed for xbt_self_thread_key");   
-  return t->start_routine(t->param);
+    THROW0(system_error,errcode,
+          "pthread_setspecific failed for xbt_self_thread_key");   
+   
+  return (*(t->start_routine))(t->param);
 }
-
-xbt_os_thread_t xbt_os_thread_create(pvoid_f_pvoid_t start_routine,
+xbt_os_thread_t xbt_os_thread_create(const char*name,
+                                    pvoid_f_pvoid_t start_routine,
                                     void* param)  {
    int errcode;
 
    xbt_os_thread_t res_thread=xbt_new(s_xbt_os_thread_t,1);
+   res_thread->name = xbt_strdup(name);
    res_thread->start_routine = start_routine;
    res_thread->param = param;
-
+   res_thread->exception = xbt_new(ex_ctx_t, 1);
+   XBT_CTX_INITIALIZE(res_thread->exception);
    
-   if ((errcode = pthread_create(&(res_thread->t), NULL, wrapper_start_routine, res_thread)))
-     THROW1(system_error,errcode, "pthread_create failed: %s",strerror(errcode));
+   if ((errcode = pthread_create(&(res_thread->t), NULL, 
+                                wrapper_start_routine, res_thread)))
+     THROW1(system_error,errcode, 
+           "pthread_create failed: %s",strerror(errcode));
 
    return res_thread;
 }
 
+const char* xbt_os_thread_name(xbt_os_thread_t t) {
+   return t->name;
+}
+
+const char* xbt_os_thread_self_name(void) {
+   xbt_os_thread_t self = xbt_os_thread_self();
+   return self?self->name:"main";
+}
 void 
 xbt_os_thread_join(xbt_os_thread_t thread,void ** thread_return) {
        
-       int errcode;   
-       
-       if ((errcode = pthread_join(thread->t,thread_return)))
-               THROW1(system_error,errcode, "pthread_join failed: %s",
-                      strerror(errcode));
-       free(thread);   
+  int errcode;   
+  
+  if ((errcode = pthread_join(thread->t,thread_return)))
+    THROW1(system_error,errcode, "pthread_join failed: %s",
+          strerror(errcode));
+   if (thread->exception)
+     free(thread->exception);
+
+   if (thread == main_thread) /* just killed main thread */
+     main_thread = NULL;
+
+   free(thread);   
 }                     
 
 void xbt_os_thread_exit(int *retval) {
@@ -90,15 +146,28 @@ void xbt_os_thread_exit(int *retval) {
 }
 
 xbt_os_thread_t xbt_os_thread_self(void) {
-   return pthread_getspecific(xbt_self_thread_key);
+  xbt_os_thread_t res;
+
+  if (!thread_mod_inited)
+    return NULL;
+  
+  res = pthread_getspecific(xbt_self_thread_key);
+  if (!res)
+    res = main_thread;
+
+  return res;
 }
 
 #include <sched.h>
 void xbt_os_thread_yield(void) {
    sched_yield();
 }
+void xbt_os_thread_cancel(xbt_os_thread_t t) {
+   pthread_cancel(t->t);
+}
 /****** mutex related functions ******/
 typedef struct xbt_os_mutex_ {
+  /* KEEP IT IN SYNC WITH xbt_thread.c */
    pthread_mutex_t m;
 } s_xbt_os_mutex_t;
 
@@ -142,6 +211,7 @@ void xbt_os_mutex_destroy(xbt_os_mutex_t mutex) {
 
 /***** condition related functions *****/
 typedef struct xbt_os_cond_ {
+  /* KEEP IT IN SYNC WITH xbt_thread.c */
    pthread_cond_t c;
 } s_xbt_os_cond_t;
 
@@ -162,6 +232,32 @@ void xbt_os_cond_wait(xbt_os_cond_t cond, xbt_os_mutex_t mutex) {
            cond,mutex, strerror(errcode));
 }
 
+#include <time.h>
+#include <math.h>
+void xbt_os_cond_timedwait(xbt_os_cond_t cond, xbt_os_mutex_t mutex, double delay) {
+   int errcode;
+   struct timespec ts_end;
+   double end = delay + xbt_os_time();
+   
+   if (delay < 0) {
+      xbt_os_cond_wait(cond,mutex);
+   } else {
+      ts_end.tv_sec = (time_t) floor(end);
+      ts_end.tv_nsec = (long)  ( ( end - ts_end.tv_sec) * 1000000000);
+      DEBUG3("pthread_cond_timedwait(%p,%p,%p)",&(cond->c),&(mutex->m), &ts_end);
+      switch ( (errcode=pthread_cond_timedwait(&(cond->c),&(mutex->m), &ts_end)) ) {
+       case 0:
+        return;
+       case ETIMEDOUT:
+        THROW3(timeout_error,errcode,"condition %p (mutex %p) wasn't signaled before timeout (%f)",
+               cond,mutex, delay);
+       default:
+        THROW4(system_error,errcode,"pthread_cond_timedwait(%p,%p,%f) failed: %s",
+               cond,mutex, delay, strerror(errcode));
+      }   
+   }
+}
+
 void xbt_os_cond_signal(xbt_os_cond_t cond) {
    int errcode;
    if ((errcode=pthread_cond_signal(&(cond->c))))
@@ -186,17 +282,143 @@ void xbt_os_cond_destroy(xbt_os_cond_t cond){
    free(cond);
 }
 
+void *xbt_os_thread_getparam(void) {
+   xbt_os_thread_t t = xbt_os_thread_self();
+   return t?t->param:NULL;
+}
+
+typedef struct xbt_os_sem_ {
+   sem_t s;
+   int pshared;
+   unsigned int value;
+   const char* name;
+}s_xbt_os_sem_t ;
+
+xbt_os_sem_t
+xbt_os_sem_init(int pshared, unsigned int value)
+{
+       xbt_os_sem_t res = xbt_new(s_xbt_os_sem_t,1);
+       
+       if(sem_init(&(res->s),pshared,value) < 0)
+               THROW1(system_error,errno,"sem_init() failed: %s",
+           strerror(errno));
+   
+   res->pshared = pshared;
+   res->value = value;
+   
+   return res;
+}
+
+void 
+xbt_os_sem_wait(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_wait() failed: %s",
+           strerror(EINVAL));
+       
+       if(sem_wait(&(sem->s)) < 0)
+               THROW1(system_error,errno,"sem_wait() failed: %s",
+           strerror(errno));            
+}
+
+void xbt_os_sem_timedwait(xbt_os_sem_t sem,const struct timespec* abs_timeout)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_timedwait() failed: %s",
+           strerror(EINVAL));
+       
+       /* only throw an exception if the global variable errno is different than ETIMEDOUT :
+        * (the semaphore could not be locked before the specified timeout expired)
+        */
+       if((sem_timedwait(&(sem->s),abs_timeout) < 0) && (ETIMEDOUT != errno))
+               THROW1(system_error,errno,"sem_wait() failed: %s",
+           strerror(errno));   
+}
+
+void 
+xbt_os_sem_post(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_post() failed: %s",
+           strerror(EINVAL));
+       
+       if(sem_post(&(sem->s)) < 0)
+               THROW1(system_error,errno,"sem_post() failed: %s",
+           strerror(errno));            
+}
+
+void
+xbt_os_sem_close(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_close() failed: %s",
+           strerror(EINVAL));
+           
+       if(sem_close(&(sem->s)) < 0)
+               THROW1(system_error,errno,"sem_close() failed: %s",
+           strerror(errno));
+}
+
+xbt_os_sem_t 
+xbt_os_sem_open(const char *name, int oflag, mode_t mode, unsigned int value)
+{
+       sem_t* ps;
+       xbt_os_sem_t res = xbt_new(s_xbt_os_sem_t,1);
+       
+       if(SEM_FAILED == (ps = sem_open(name,oflag, mode, value)))
+               THROW1(system_error,errno,"sem_open() failed: %s",
+           strerror(errno));
+       
+   res->s = *ps;
+   res->value = value;
+   
+   return res; 
+}
+
+void
+xbt_os_sem_destroy(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_destroy() failed: %s",
+           strerror(EINVAL));
+           
+       if(sem_destroy(&(sem->s)) < 0)
+               THROW1(system_error,errno,"sem_destroy() failed: %s",
+           strerror(errno));
+}
+
+void
+xbt_os_sem_get_value(xbt_os_sem_t sem, int* svalue)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_getvalue() failed: %s",
+           strerror(EINVAL));
+           
+       if(sem_getvalue(&(sem->s),svalue) < 0)
+               THROW1(system_error,errno,"sem_getvalue() failed: %s",
+           strerror(errno));
+}
+
 /* ********************************* WINDOWS IMPLEMENTATION ************************************ */
 
 #elif defined(WIN32)
 
 typedef struct xbt_os_thread_ {
+  char *name;
   HANDLE handle;                  /* the win thread handle        */
   unsigned long id;               /* the win thread id            */
-  pvoid_f_pvoid_t *start_routine;
+  pvoid_f_pvoid_t start_routine;
   void* param;
 } s_xbt_os_thread_t ;
 
+/* so we can specify the size of the stack of the threads */
+#ifndef STACK_SIZE_PARAM_IS_A_RESERVATION
+#define STACK_SIZE_PARAM_IS_A_RESERVATION 0x00010000
+#endif
+
+/* the default size of the stack of the threads (in bytes)*/
+#define XBT_DEFAULT_THREAD_STACK_SIZE  4096
+
 /* key to the TLS containing the xbt_os_thread_t structure */
 static unsigned long xbt_self_thread_key;
 
@@ -211,25 +433,29 @@ void xbt_os_thread_mod_exit(void) {
 
 static DWORD WINAPI  wrapper_start_routine(void *s) {
   xbt_os_thread_t t = (xbt_os_thread_t)s;
+  void* rv;
  
     if(!TlsSetValue(xbt_self_thread_key,t))
      THROW0(system_error,(int)GetLastError(),"TlsSetValue of data describing the created thread failed");
    
-   return (DWORD)t->start_routine(t->param);
+   rv = (*(t->start_routine))(t->param);
+
+   return *((DWORD*)rv);
 }
 
 
-xbt_os_thread_t xbt_os_thread_create(pvoid_f_pvoid_t start_routine,
+xbt_os_thread_t xbt_os_thread_create(const char *name,pvoid_f_pvoid_t start_routine,
                               void* param)  {
    
    xbt_os_thread_t t = xbt_new(s_xbt_os_thread_t,1);
 
+   t->name = xbt_strdup(name);
    t->start_routine = start_routine ;
    t->param = param;
    
-   t->handle = CreateThread(NULL,0,
+   t->handle = CreateThread(NULL,XBT_DEFAULT_THREAD_STACK_SIZE,
                            (LPTHREAD_START_ROUTINE)wrapper_start_routine,
-                           t,0,&(t->id));
+                           t,STACK_SIZE_PARAM_IS_A_RESERVATION,&(t->id));
        
    if(!t->handle) {
      xbt_free(t);
@@ -239,6 +465,15 @@ xbt_os_thread_t xbt_os_thread_create(pvoid_f_pvoid_t start_routine,
    return t;
 }
 
+const char* xbt_os_thread_name(xbt_os_thread_t t) {
+   return t->name;
+}
+
+const char* xbt_os_thread_self_name(void) {
+   xbt_os_thread_t t = xbt_os_thread_self();
+   return t?t->name:"main";
+}
+
 void 
 xbt_os_thread_join(xbt_os_thread_t thread,void ** thread_return) {
 
@@ -252,6 +487,7 @@ xbt_os_thread_join(xbt_os_thread_t thread,void ** thread_return) {
        }
        
        CloseHandle(thread->handle);
+       free(thread->name);
        free(thread);
 }
 
@@ -266,12 +502,22 @@ xbt_os_thread_t xbt_os_thread_self(void) {
    return TlsGetValue(xbt_self_thread_key);
 }
 
+void *xbt_os_thread_getparam(void) {
+   xbt_os_thread_t t = xbt_os_thread_self();
+   return t->param;
+}
+
+
 void xbt_os_thread_yield(void) {
     Sleep(0);
 }
+void xbt_os_thread_cancel(xbt_os_thread_t t) {
+   THROW_UNIMPLEMENTED;
+}
 
 /****** mutex related functions ******/
 typedef struct xbt_os_mutex_ {
+  /* KEEP IT IN SYNC WITH xbt_thread.c */
    CRITICAL_SECTION lock;   
 } s_xbt_os_mutex_t;
 
@@ -304,13 +550,14 @@ void xbt_os_mutex_destroy(xbt_os_mutex_t mutex) {
 }
 
 /***** condition related functions *****/
- enum {
+ enum { /* KEEP IT IN SYNC WITH xbt_thread.c */
     SIGNAL = 0,
     BROADCAST = 1,
     MAX_EVENTS = 2
  };
 
 typedef struct xbt_os_cond_ {
+  /* KEEP IT IN SYNC WITH xbt_thread.c */
    HANDLE events[MAX_EVENTS];
    
    unsigned int waiters_count;           /* the number of waiters                        */
@@ -390,6 +637,58 @@ void xbt_os_cond_wait(xbt_os_cond_t cond, xbt_os_mutex_t mutex) {
    /* relock the mutex associated with the condition in accordance with the posix thread specification */
    EnterCriticalSection (& mutex->lock);
 }
+void xbt_os_cond_timedwait(xbt_os_cond_t cond, xbt_os_mutex_t mutex, double delay) {
+   
+        unsigned long wait_result = WAIT_TIMEOUT;
+   int is_last_waiter;
+   unsigned long end = (unsigned long)(delay * 1000);
+
+
+   if (delay < 0) {
+      xbt_os_cond_wait(cond,mutex);
+   } else {
+         DEBUG3("xbt_cond_timedwait(%p,%p,%ul)",&(cond->events),&(mutex->lock),end);
+
+   /* lock the threads counter and increment it */
+   EnterCriticalSection (& cond->waiters_count_lock);
+   cond->waiters_count++;
+   LeaveCriticalSection (& cond->waiters_count_lock);
+               
+   /* unlock the mutex associate with the condition */
+   LeaveCriticalSection (& mutex->lock);
+   /* wait for a signal (broadcast or no) */
+       
+   wait_result = WaitForMultipleObjects (2, cond->events, FALSE, end);
+       
+   switch(wait_result) {
+     case WAIT_TIMEOUT:
+       THROW3(timeout_error,GetLastError(),"condition %p (mutex %p) wasn't signaled before timeout (%f)",cond,mutex, delay);
+       case WAIT_FAILED:
+     THROW0(system_error,GetLastError(),"WaitForMultipleObjects failed, so we cannot wait on the condition");
+   }
+       
+   /* we have a signal lock the condition */
+   EnterCriticalSection (& cond->waiters_count_lock);
+   cond->waiters_count--;
+       
+   /* it's the last waiter or it's a broadcast ? */
+   is_last_waiter = ((wait_result == WAIT_OBJECT_0 + BROADCAST - 1) && (cond->waiters_count == 0));
+       
+   LeaveCriticalSection (& cond->waiters_count_lock);
+       
+   /* yes it's the last waiter or it's a broadcast
+    * only reset the manual event (the automatic event is reset in the WaitForMultipleObjects() function
+    * by the system. 
+    */
+   if (is_last_waiter)
+      if(!ResetEvent (cond->events[BROADCAST]))
+       THROW0(system_error,0,"ResetEvent failed");
+       
+   /* relock the mutex associated with the condition in accordance with the posix thread specification */
+   EnterCriticalSection (& mutex->lock);
+   }
+       /*THROW_UNIMPLEMENTED;*/
+}
 
 void xbt_os_cond_signal(xbt_os_cond_t cond) {
    int have_waiters;
@@ -435,4 +734,152 @@ void xbt_os_cond_destroy(xbt_os_cond_t cond){
      THROW0(system_error,0,"Error while destroying the condition");
 }
 
+typedef struct xbt_os_sem_ {
+   HANDLE h;
+   unsigned int value;
+   const char* name;
+   CRITICAL_SECTION value_lock;  /* protect access to value of the semaphore  */
+}s_xbt_os_sem_t ;
+
+xbt_os_sem_t
+xbt_os_sem_init(int pshared, unsigned int value)
+{
+       xbt_os_sem_t res;
+       
+       if(0 != pshared)
+       THROW1(arg_error,EPERM,"xbt_os_sem_init() failed: %s",
+           strerror(EPERM));
+           
+       if(value > INT_MAX)
+       THROW1(arg_error,EINVAL,"xbt_os_sem_init() failed: %s",
+           strerror(EINVAL));
+       
+       res = (xbt_os_sem_t)xbt_new0(s_xbt_os_sem_t,1);
+       
+       if(!(res->h = CreateSemaphore(NULL,value,(long)INT_MAX,NULL))) {
+               THROW1(system_error,GetLastError(),"CreateSemaphore() failed: %s",
+           strerror(GetLastError()));
+           return NULL;
+       }
+  
+       res->value = value;
+       
+       InitializeCriticalSection(&(res->value_lock));
+   
+       return res;
+}
+
+void 
+xbt_os_sem_wait(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_wait() failed: %s",
+           strerror(EINVAL));  
+
+       /* wait failure */
+       if(WAIT_OBJECT_0 != WaitForSingleObject(sem->h,INFINITE))
+               THROW1(system_error,GetLastError(),"WaitForSingleObject() failed: %s",
+               strerror(GetLastError()));
+       EnterCriticalSection(&(sem->value_lock));
+       sem->value--;
+       LeaveCriticalSection(&(sem->value_lock));
+}
+
+void xbt_os_sem_timedwait(xbt_os_sem_t sem,const struct timespec* abs_timeout)
+{
+       long timeout;
+       struct timeval tv;
+       
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_timedwait() failed: %s",
+           strerror(EINVAL));  
+           
+       if(!abs_timeout)
+               timeout = INFINITE;
+       else
+       {
+               if(gettimeofday(&tv, NULL) < 0) 
+                       THROW1(system_error,errno,"gettimeofday() failed: %s",
+               strerror(errno));       
+                       
+                timeout = ((long) (abs_timeout->tv_sec - tv.tv_sec) * 1e3 + (long)((abs_timeout->tv_nsec / 1e3) - tv.tv_usec) / 1e3);          
+       }
+       
+       switch(WaitForSingleObject(sem->h,timeout))
+       {
+               case WAIT_OBJECT_0:
+               EnterCriticalSection(&(sem->value_lock));
+               sem->value--;
+               LeaveCriticalSection(&(sem->value_lock));
+               return;
+               
+               case WAIT_TIMEOUT:
+               /* it's not an exception : 
+                * (semaphore could not be locked before the specified timeout expired)
+                */
+               return;
+               
+               default:
+                       
+               THROW1(system_error,GetLastError(),"WaitForSingleObject() failed: %s",
+               strerror(GetLastError()));
+       }
+}
+
+void 
+xbt_os_sem_post(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_post() failed: %s",
+           strerror(EINVAL));
+       
+       if(!ReleaseSemaphore(sem->h,1, NULL)) 
+               THROW1(system_error,GetLastError(),"ReleaseSemaphore() failed: %s",
+               strerror(GetLastError()));
+       EnterCriticalSection (&(sem->value_lock));
+       sem->value++;
+       LeaveCriticalSection(&(sem->value_lock));
+}
+
+xbt_os_sem_t 
+xbt_os_sem_open(const char *name, int oflag, mode_t mode, unsigned int value)
+{
+       THROW_UNIMPLEMENTED;
+}
+
+void
+xbt_os_sem_close(xbt_os_sem_t sem)
+{
+       THROW_UNIMPLEMENTED;
+}
+
+void
+xbt_os_sem_destroy(xbt_os_sem_t sem)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_destroy() failed: %s",
+           strerror(EINVAL));
+       
+       if(!CloseHandle(sem->h)) 
+               THROW1(system_error,GetLastError(),"CloseHandle() failed: %s",
+               strerror(GetLastError()));
+        
+        DeleteCriticalSection(&(sem->value_lock));
+               
+        xbt_free(sem);     
+               
+}
+
+void
+xbt_os_sem_get_value(xbt_os_sem_t sem, int* svalue)
+{
+       if(!sem)
+               THROW1(arg_error,EINVAL,"xbt_os_sem_get_value() failed: %s",
+           strerror(EINVAL));
+       
+       EnterCriticalSection(&(sem->value_lock));  
+       *svalue = sem->value;
+       LeaveCriticalSection(&(sem->value_lock));
+}
+
 #endif