DMTCP
 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Macros Pages
Classes | Macros | Typedefs | Enumerations | Functions | Variables
syscallwrappers.h File Reference
#include <features.h>
#include <pthread.h>
#include <stdio.h>
#include <sys/types.h>
#include <sys/socket.h>
#include <signal.h>
#include <sys/wait.h>
#include <poll.h>
#include <stdarg.h>
#include <sys/shm.h>
#include <sys/sem.h>
#include <sys/msg.h>
#include <sys/stat.h>
#include <sys/mman.h>
#include <dirent.h>
#include <unistd.h>
#include <mqueue.h>
#include "constants.h"
#include "dmtcp.h"
#include "mtcp/ldt.h"
#include "config.h"

Go to the source code of this file.

Classes

struct  epoll_event
 
union  semun
 

Macros

#define __USE_LARGEFILE64_not_defined
 
#define __USE_LARGEFILE64
 
#define _SYS_EPOLL_H   1
 
#define EPOLL_CTL_ADD   1 /* Add a file decriptor to the interface. */
 
#define EPOLL_CTL_DEL   2 /* Remove a file decriptor from the interface. */
 
#define EPOLL_CTL_MOD   3 /* Change file decriptor epoll_event structure. */
 
#define FOREACH_GLIBC_MALLOC_FAMILY_WRAPPERS(MACRO)
 
#define FOREACH_GLIBC_WRAPPERS(MACRO)
 
#define FOREACH_LIBPTHREAD_WRAPPERS(MACRO)
 
#define FOREACH_DMTCP_WRAPPER(MACRO)
 
#define ENUM(x)   enum_ ## x
 
#define GEN_ENUM(x)   ENUM(x),
 

Typedefs

typedef void(* sighandler_t )(int)
 

Enumerations

enum  LibcWrapperOffset { numLibcWrappers }
 

Functions

void _dmtcp_setup_trampolines ()
 
LIB_PRIVATE pid_t dmtcp_gettid ()
 
LIB_PRIVATE int dmtcp_tkill (int tid, int sig)
 
LIB_PRIVATE int dmtcp_tgkill (int tgid, int tid, int sig)
 
void _dmtcp_lock ()
 
void _dmtcp_unlock ()
 
void _dmtcp_remutex_on_fork ()
 
LIB_PRIVATE void dmtcpResetTid (pid_t tid)
 
LIB_PRIVATE void dmtcpResetPidPpid ()
 
int _dmtcp_unsetenv (const char *name)
 
void initialize_libc_wrappers ()
 
void initialize_libpthread_wrappers ()
 
int _real_socket (int domain, int type, int protocol)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_connect (int sockfd, const struct sockaddr *serv_addr, socklen_t addrlen)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_bind (int sockfd, const struct sockaddr *my_addr, socklen_t addrlen)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_listen (int sockfd, int backlog)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_accept (int sockfd, struct sockaddr *addr, socklen_t *addrlen)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_accept4 (int sockfd, struct sockaddr *addr, socklen_t *addrlen, int flags)
 
int _real_setsockopt (int s, int level, int optname, const void *optval, socklen_t optlen)
 call the libc version of this function via dlopen/dlsym More...
 
int _real_getsockopt (int s, int level, int optname, void *optval, socklen_t *optlen)
 
int _real_fexecve (int fd, char *const argv[], char *const envp[])
 
int _real_execve (const char *filename, char *const argv[], char *const envp[])
 
int _real_execv (const char *path, char *const argv[])
 
int _real_execvp (const char *file, char *const argv[])
 
int _real_execvpe (const char *file, char *const argv[], char *const envp[])
 
int _real_system (const char *cmd)
 
FILE * _real_popen (const char *command, const char *mode)
 
int _real_pclose (FILE *fp)
 
pid_t _real_fork ()
 
int _real_clone (int(*fn)(void *arg), void *child_stack, int flags, void *arg, int *parent_tidptr, struct user_desc *newtls, int *child_tidptr)
 
int _real_open (const char *pathname, int flags,...)
 
int _real_open64 (const char *pathname, int flags,...)
 
FILE * _real_fopen (const char *path, const char *mode)
 
FILE * _real_fopen64 (const char *path, const char *mode)
 
int _real_openat (int dirfd, const char *pathname, int flags, mode_t mode)
 
int _real_openat64 (int dirfd, const char *pathname, int flags, mode_t mode)
 
DIR * _real_opendir (const char *name)
 
int _real_mkstemp (char *ttemplate)
 
int _real_close (int fd)
 
int _real_fclose (FILE *fp)
 
int _real_closedir (DIR *dir)
 
void _real_exit (int status)
 
int _real_dup (int oldfd)
 
int _real_dup2 (int oldfd, int newfd)
 
int _real_dup3 (int oldfd, int newfd, int flags)
 
int _real_fcntl (int fd, int cmd, void *arg)
 
int _real_ttyname_r (int fd, char *buf, size_t buflen)
 
int _real_ptsname_r (int fd, char *buf, size_t buflen)
 
int _real_getpt (void)
 
int _real_posix_openpt (int flags)
 
int _real_socketpair (int d, int type, int protocol, int sv[2])
 
void _real_openlog (const char *ident, int option, int facility)
 
void _real_closelog (void)
 
sighandler_t _real_signal (int signum, sighandler_t handler)
 
int _real_sigaction (int signum, const struct sigaction *act, struct sigaction *oldact)
 
int _real_rt_sigaction (int signum, const struct sigaction *act, struct sigaction *oldact)
 
int _real_sigvec (int sig, const struct sigvec *vec, struct sigvec *ovec)
 
int _real_sigblock (int mask)
 
int _real_sigsetmask (int mask)
 
int _real_siggetmask (void)
 
int _real_sigprocmask (int how, const sigset_t *set, sigset_t *oldset)
 
int _real_rt_sigprocmask (int how, const sigset_t *set, sigset_t *oldset)
 
int _real_pthread_sigmask (int how, const sigset_t *newmask, sigset_t *oldmask)
 
void * _real_pthread_getspecific (pthread_key_t key)
 
int _real_sigsuspend (const sigset_t *mask)
 
int _real_sighold (int sig)
 
int _real_sigignore (int sig)
 
int _real__sigpause (int __sig_or_mask, int __is_sig)
 
int _real_sigpause (int sig)
 
int _real_sigrelse (int sig)
 
sighandler_t _real_sigset (int sig, sighandler_t disp)
 
int _real_sigwait (const sigset_t *set, int *sig)
 
int _real_sigwaitinfo (const sigset_t *set, siginfo_t *info)
 
int _real_sigtimedwait (const sigset_t *set, siginfo_t *info, const struct timespec *timeout)
 
long _real_syscall (long sys_num,...)
 
int _real_pthread_create (pthread_t *thread, const pthread_attr_t *attr, void *(*start_routine)(void *), void *arg)
 
void _real_pthread_exit (void *retval) __attribute__((__noreturn__))
 
int _real_pthread_tryjoin_np (pthread_t thread, void **retval)
 
int _real_pthread_timedjoin_np (pthread_t thread, void **retval, const struct timespec *abstime)
 
int _real_xstat (int vers, const char *path, struct stat *buf)
 
int _real_xstat64 (int vers, const char *path, struct stat64 *buf)
 
int _real_lxstat (int vers, const char *path, struct stat *buf)
 
int _real_lxstat64 (int vers, const char *path, struct stat64 *buf)
 
ssize_t _real_readlink (const char *path, char *buf, size_t bufsiz)
 
void * _real_dlsym (void *handle, const char *symbol)
 
void * _real_dlopen (const char *filename, int flag)
 
int _real_dlclose (void *handle)
 
void * _real_calloc (size_t nmemb, size_t size)
 
void * _real_malloc (size_t size)
 
void _real_free (void *ptr)
 
void * _real_realloc (void *ptr, size_t size)
 
void * _real_libc_memalign (size_t boundary, size_t size)
 
void * _real_mmap (void *addr, size_t length, int prot, int flags, int fd, off_t offset)
 
void * _real_mmap64 (void *addr, size_t length, int prot, int flags, int fd, __off64_t offset)
 
void * _real_mremap (void *old_address, size_t old_size, size_t new_size, int flags)
 
int _real_munmap (void *addr, size_t length)
 
ssize_t _real_read (int fd, void *buf, size_t count)
 
ssize_t _real_write (int fd, const void *buf, size_t count)
 
int _real_select (int nfds, fd_set *readfds, fd_set *writefds, fd_set *exceptfds, struct timeval *timeout)
 
off_t _real_lseek (int fd, off_t offset, int whence)
 
int _real_unlink (const char *pathname)
 
int _real_pthread_mutex_lock (pthread_mutex_t *mutex)
 
int _real_pthread_mutex_trylock (pthread_mutex_t *mutex)
 
int _real_pthread_mutex_unlock (pthread_mutex_t *mutex)
 
int _real_pthread_rwlock_unlock (pthread_rwlock_t *rwlock)
 
int _real_pthread_rwlock_rdlock (pthread_rwlock_t *rwlock)
 
int _real_pthread_rwlock_tryrdlock (pthread_rwlock_t *rwlock)
 
int _real_pthread_rwlock_wrlock (pthread_rwlock_t *rwlock)
 
int _real_pthread_rwlock_trywrlock (pthread_rwlock_t *rwlock)
 
int _real_pthread_cond_broadcast (pthread_cond_t *cond)
 
int _real_pthread_cond_destroy (pthread_cond_t *cond)
 
int _real_pthread_cond_init (pthread_cond_t *cond, const pthread_condattr_t *attr)
 
int _real_pthread_cond_signal (pthread_cond_t *cond)
 
int _real_pthread_cond_timedwait (pthread_cond_t *cond, pthread_mutex_t *mutex, const struct timespec *abstime)
 
int _real_pthread_cond_wait (pthread_cond_t *cond, pthread_mutex_t *mutex)
 
int _real_poll (struct pollfd *fds, nfds_t nfds, int timeout)
 
int _real_waitid (idtype_t idtype, id_t id, siginfo_t *infop, int options)
 
pid_t _real_wait4 (pid_t pid, __WAIT_STATUS status, int options, struct rusage *rusage)
 
int _real_shmget (int key, size_t size, int shmflg)
 
void * _real_shmat (int shmid, const void *shmaddr, int shmflg)
 
int _real_shmdt (const void *shmaddr)
 
int _real_shmctl (int shmid, int cmd, struct shmid_ds *buf)
 
int _real_semget (key_t key, int nsems, int semflg)
 
int _real_semop (int semid, struct sembuf *sops, size_t nsops)
 
int _real_semtimedop (int semid, struct sembuf *sops, size_t nsops, const struct timespec *timeout)
 
int _real_semctl (int semid, int semnum, int cmd,...)
 
int _real_msgget (key_t key, int msgflg)
 
int _real_msgsnd (int msqid, const void *msgp, size_t msgsz, int msgflg)
 
ssize_t _real_msgrcv (int msqid, void *msgp, size_t msgsz, long msgtyp, int msgflg)
 
int _real_msgctl (int msqid, int cmd, struct msqid_ds *buf)
 
mqd_t _real_mq_open (const char *name, int oflag, mode_t mode, struct mq_attr *attr)
 
int _real_mq_close (mqd_t mqdes)
 
int _real_mq_notify (mqd_t mqdes, const struct sigevent *sevp)
 
ssize_t _real_mq_timedreceive (mqd_t mqdes, char *msg_ptr, size_t msg_len, unsigned int *msg_prio, const struct timespec *abs_timeout)
 
int _real_mq_timedsend (mqd_t mqdes, const char *msg_ptr, size_t msg_len, unsigned int msg_prio, const struct timespec *abs_timeout)
 

Variables

int dmtcp_wrappers_initializing
 
LIB_PRIVATE __thread int thread_performing_dlopen_dlsym
 

Macro Definition Documentation

#define __USE_LARGEFILE64

Definition at line 43 of file syscallwrappers.h.

#define __USE_LARGEFILE64_not_defined

Definition at line 42 of file syscallwrappers.h.

#define _SYS_EPOLL_H   1

Definition at line 69 of file syscallwrappers.h.

#define ENUM (   x)    enum_ ## x

Definition at line 263 of file syscallwrappers.h.

#define EPOLL_CTL_ADD   1 /* Add a file decriptor to the interface. */

Definition at line 72 of file syscallwrappers.h.

#define EPOLL_CTL_DEL   2 /* Remove a file decriptor from the interface. */

Definition at line 73 of file syscallwrappers.h.

#define EPOLL_CTL_MOD   3 /* Change file decriptor epoll_event structure. */

Definition at line 74 of file syscallwrappers.h.

#define FOREACH_DMTCP_WRAPPER (   MACRO)
Value:
FOREACH_GLIBC_MALLOC_FAMILY_WRAPPERS(MACRO)

Definition at line 259 of file syscallwrappers.h.

#define FOREACH_GLIBC_MALLOC_FAMILY_WRAPPERS (   MACRO)
Value:
MACRO(calloc) \
MACRO(malloc) \
MACRO(free) \
MACRO(__libc_memalign) \
MACRO(realloc) \
MACRO(mmap) \
MACRO(mmap64) \
MACRO(mremap) \
MACRO(munmap)

Definition at line 97 of file syscallwrappers.h.

#define FOREACH_GLIBC_WRAPPERS (   MACRO)

Definition at line 108 of file syscallwrappers.h.

#define FOREACH_LIBPTHREAD_WRAPPERS (   MACRO)
Value:

Definition at line 251 of file syscallwrappers.h.

#define GEN_ENUM (   x)    ENUM(x),

Definition at line 264 of file syscallwrappers.h.

Typedef Documentation

typedef void(* sighandler_t)(int)

Definition at line 347 of file syscallwrappers.h.

Enumeration Type Documentation

Enumerator
numLibcWrappers 

Definition at line 265 of file syscallwrappers.h.

Function Documentation

void _dmtcp_lock ( )

Definition at line 92 of file nosyscallsreal.c.

void _dmtcp_remutex_on_fork ( )

Definition at line 70 of file syscallsreal.c.

void _dmtcp_setup_trampolines ( )

Definition at line 48 of file dmtcpnohijackstubs.cpp.

void _dmtcp_unlock ( )

Definition at line 93 of file nosyscallsreal.c.

int _dmtcp_unsetenv ( const char *  name)

Definition at line 261 of file nosyscallsreal.c.

int _real__sigpause ( int  __sig_or_mask,
int  __is_sig 
)

Definition at line 776 of file syscallsreal.c.

int _real_accept ( int  sockfd,
struct sockaddr *  addr,
socklen_t *  addrlen 
)

call the libc version of this function via dlopen/dlsym

Definition at line 161 of file nosyscallsreal.c.

int _real_accept4 ( int  sockfd,
struct sockaddr *  addr,
socklen_t *  addrlen,
int  flags 
)

Definition at line 558 of file syscallsreal.c.

int _real_bind ( int  sockfd,
const struct sockaddr *  my_addr,
socklen_t  addrlen 
)

call the libc version of this function via dlopen/dlsym

Definition at line 149 of file nosyscallsreal.c.

void* _real_calloc ( size_t  nmemb,
size_t  size 
)
int _real_clone ( int(*)(void *arg)  fn,
void *  child_stack,
int  flags,
void *  arg,
int *  parent_tidptr,
struct user_desc newtls,
int *  child_tidptr 
)
int _real_close ( int  fd)

Definition at line 205 of file nosyscallsreal.c.

int _real_closedir ( DIR *  dir)

Definition at line 865 of file syscallsreal.c.

void _real_closelog ( void  )

Definition at line 256 of file nosyscallsreal.c.

int _real_connect ( int  sockfd,
const struct sockaddr *  serv_addr,
socklen_t  addrlen 
)

call the libc version of this function via dlopen/dlsym

Definition at line 143 of file nosyscallsreal.c.

int _real_dlclose ( void *  handle)

Definition at line 397 of file syscallsreal.c.

void* _real_dlopen ( const char *  filename,
int  flag 
)

Definition at line 392 of file syscallsreal.c.

void* _real_dlsym ( void *  handle,
const char *  symbol 
)

Definition at line 113 of file pid_syscallsreal.c.

int _real_dup ( int  oldfd)

Definition at line 215 of file nosyscallsreal.c.

int _real_dup2 ( int  oldfd,
int  newfd 
)

Definition at line 220 of file nosyscallsreal.c.

int _real_dup3 ( int  oldfd,
int  newfd,
int  flags 
)

Definition at line 654 of file syscallsreal.c.

int _real_execv ( const char *  path,
char *const  argv[] 
)

Definition at line 185 of file nosyscallsreal.c.

int _real_execve ( const char *  filename,
char *const  argv[],
char *const  envp[] 
)

Definition at line 179 of file nosyscallsreal.c.

int _real_execvp ( const char *  file,
char *const  argv[] 
)

Definition at line 190 of file nosyscallsreal.c.

int _real_execvpe ( const char *  file,
char *const  argv[],
char *const  envp[] 
)

Definition at line 603 of file syscallsreal.c.

void _real_exit ( int  status)

Definition at line 230 of file nosyscallsreal.c.

int _real_fclose ( FILE *  fp)

Definition at line 210 of file nosyscallsreal.c.

int _real_fcntl ( int  fd,
int  cmd,
void *  arg 
)

Definition at line 236 of file nosyscallsreal.c.

int _real_fexecve ( int  fd,
char *const  argv[],
char *const  envp[] 
)

Definition at line 579 of file syscallsreal.c.

FILE* _real_fopen ( const char *  path,
const char *  mode 
)

Definition at line 412 of file nosyscallsreal.c.

FILE* _real_fopen64 ( const char *  path,
const char *  mode 
)

Definition at line 416 of file nosyscallsreal.c.

pid_t _real_fork ( )

Definition at line 200 of file nosyscallsreal.c.

void _real_free ( void *  ptr)
int _real_getpt ( void  )

Definition at line 672 of file syscallsreal.c.

int _real_getsockopt ( int  s,
int  level,
int  optname,
void *  optval,
socklen_t *  optlen 
)

Definition at line 173 of file nosyscallsreal.c.

void* _real_libc_memalign ( size_t  boundary,
size_t  size 
)
int _real_listen ( int  sockfd,
int  backlog 
)

call the libc version of this function via dlopen/dlsym

Definition at line 155 of file nosyscallsreal.c.

off_t _real_lseek ( int  fd,
off_t  offset,
int  whence 
)

Definition at line 265 of file nosyscallsreal.c.

int _real_lxstat ( int  vers,
const char *  path,
struct stat *  buf 
)

Definition at line 402 of file pid_syscallsreal.c.

int _real_lxstat64 ( int  vers,
const char *  path,
struct stat64 *  buf 
)

Definition at line 406 of file pid_syscallsreal.c.

void* _real_malloc ( size_t  size)
int _real_mkstemp ( char *  ttemplate)

Definition at line 870 of file syscallsreal.c.

void* _real_mmap ( void *  addr,
size_t  length,
int  prot,
int  flags,
int  fd,
off_t  offset 
)

Definition at line 349 of file nosyscallsreal.c.

void* _real_mmap64 ( void *  addr,
size_t  length,
int  prot,
int  flags,
int  fd,
__off64_t  offset 
)

Definition at line 1073 of file syscallsreal.c.

int _real_mq_close ( mqd_t  mqdes)

Definition at line 1040 of file syscallsreal.c.

int _real_mq_notify ( mqd_t  mqdes,
const struct sigevent *  sevp 
)

Definition at line 331 of file pid_syscallsreal.c.

mqd_t _real_mq_open ( const char *  name,
int  oflag,
mode_t  mode,
struct mq_attr *  attr 
)

Definition at line 1034 of file syscallsreal.c.

ssize_t _real_mq_timedreceive ( mqd_t  mqdes,
char *  msg_ptr,
size_t  msg_len,
unsigned int *  msg_prio,
const struct timespec *  abs_timeout 
)

Definition at line 1050 of file syscallsreal.c.

int _real_mq_timedsend ( mqd_t  mqdes,
const char *  msg_ptr,
size_t  msg_len,
unsigned int  msg_prio,
const struct timespec *  abs_timeout 
)

Definition at line 1059 of file syscallsreal.c.

void* _real_mremap ( void *  old_address,
size_t  old_size,
size_t  new_size,
int  flags 
)

Definition at line 1096 of file syscallsreal.c.

int _real_msgctl ( int  msqid,
int  cmd,
struct msqid_ds *  buf 
)

Definition at line 325 of file pid_syscallsreal.c.

int _real_msgget ( key_t  key,
int  msgflg 
)

Definition at line 1012 of file syscallsreal.c.

ssize_t _real_msgrcv ( int  msqid,
void *  msgp,
size_t  msgsz,
long  msgtyp,
int  msgflg 
)

Definition at line 1022 of file syscallsreal.c.

int _real_msgsnd ( int  msqid,
const void *  msgp,
size_t  msgsz,
int  msgflg 
)

Definition at line 1017 of file syscallsreal.c.

int _real_munmap ( void *  addr,
size_t  length 
)

Definition at line 355 of file nosyscallsreal.c.

int _real_open ( const char *  pathname,
int  flags,
  ... 
)

Definition at line 388 of file nosyscallsreal.c.

int _real_open64 ( const char *  pathname,
int  flags,
  ... 
)

Definition at line 400 of file nosyscallsreal.c.

int _real_openat ( int  dirfd,
const char *  pathname,
int  flags,
mode_t  mode 
)

Definition at line 850 of file syscallsreal.c.

int _real_openat64 ( int  dirfd,
const char *  pathname,
int  flags,
mode_t  mode 
)

Definition at line 855 of file syscallsreal.c.

DIR* _real_opendir ( const char *  name)

Definition at line 860 of file syscallsreal.c.

void _real_openlog ( const char *  ident,
int  option,
int  facility 
)

Definition at line 251 of file nosyscallsreal.c.

int _real_pclose ( FILE *  fp)

Definition at line 619 of file syscallsreal.c.

int _real_poll ( struct pollfd *  fds,
nfds_t  nfds,
int  timeout 
)

Definition at line 437 of file nosyscallsreal.c.

FILE* _real_popen ( const char *  command,
const char *  mode 
)

Definition at line 614 of file syscallsreal.c.

int _real_posix_openpt ( int  flags)

Definition at line 678 of file syscallsreal.c.

int _real_pthread_cond_broadcast ( pthread_cond_t *  cond)

Definition at line 442 of file syscallsreal.c.

int _real_pthread_cond_destroy ( pthread_cond_t *  cond)

Definition at line 453 of file syscallsreal.c.

int _real_pthread_cond_init ( pthread_cond_t *  cond,
const pthread_condattr_t *  attr 
)

Definition at line 464 of file syscallsreal.c.

int _real_pthread_cond_signal ( pthread_cond_t *  cond)

Definition at line 476 of file syscallsreal.c.

int _real_pthread_cond_timedwait ( pthread_cond_t *  cond,
pthread_mutex_t *  mutex,
const struct timespec *  abstime 
)

Definition at line 487 of file syscallsreal.c.

int _real_pthread_cond_wait ( pthread_cond_t *  cond,
pthread_mutex_t *  mutex 
)

Definition at line 499 of file syscallsreal.c.

int _real_pthread_create ( pthread_t *  thread,
const pthread_attr_t *  attr,
void *(*)(void *)  start_routine,
void *  arg 
)

Definition at line 936 of file syscallsreal.c.

void _real_pthread_exit ( void *  retval)

Definition at line 348 of file pid_syscallsreal.c.

void* _real_pthread_getspecific ( pthread_key_t  key)

Definition at line 752 of file syscallsreal.c.

int _real_pthread_mutex_lock ( pthread_mutex_t *  mutex)

Definition at line 99 of file nosyscallsreal.c.

int _real_pthread_mutex_trylock ( pthread_mutex_t *  mutex)

Definition at line 103 of file nosyscallsreal.c.

int _real_pthread_mutex_unlock ( pthread_mutex_t *  mutex)

Definition at line 107 of file nosyscallsreal.c.

int _real_pthread_rwlock_rdlock ( pthread_rwlock_t *  rwlock)

Definition at line 115 of file nosyscallsreal.c.

int _real_pthread_rwlock_tryrdlock ( pthread_rwlock_t *  rwlock)

Definition at line 427 of file syscallsreal.c.

int _real_pthread_rwlock_trywrlock ( pthread_rwlock_t *  rwlock)

Definition at line 437 of file syscallsreal.c.

int _real_pthread_rwlock_unlock ( pthread_rwlock_t *  rwlock)

Definition at line 111 of file nosyscallsreal.c.

int _real_pthread_rwlock_wrlock ( pthread_rwlock_t *  rwlock)

Definition at line 119 of file nosyscallsreal.c.

int _real_pthread_sigmask ( int  how,
const sigset_t *  newmask,
sigset_t *  oldmask 
)

Definition at line 747 of file syscallsreal.c.

int _real_pthread_timedjoin_np ( pthread_t  thread,
void **  retval,
const struct timespec *  abstime 
)

Definition at line 930 of file syscallsreal.c.

int _real_pthread_tryjoin_np ( pthread_t  thread,
void **  retval 
)

Definition at line 925 of file syscallsreal.c.

int _real_ptsname_r ( int  fd,
char *  buf,
size_t  buflen 
)

Definition at line 241 of file nosyscallsreal.c.

ssize_t _real_read ( int  fd,
void *  buf,
size_t  count 
)

Definition at line 123 of file nosyscallsreal.c.

ssize_t _real_readlink ( const char *  path,
char *  buf,
size_t  bufsiz 
)

Definition at line 441 of file nosyscallsreal.c.

void* _real_realloc ( void *  ptr,
size_t  size 
)
int _real_rt_sigaction ( int  signum,
const struct sigaction act,
struct sigaction oldact 
)
int _real_rt_sigprocmask ( int  how,
const sigset_t *  set,
sigset_t *  oldset 
)
int _real_select ( int  nfds,
fd_set *  readfds,
fd_set *  writefds,
fd_set *  exceptfds,
struct timeval *  timeout 
)

Definition at line 131 of file nosyscallsreal.c.

int _real_semctl ( int  semid,
int  semnum,
int  cmd,
  ... 
)

Definition at line 315 of file pid_syscallsreal.c.

int _real_semget ( key_t  key,
int  nsems,
int  semflg 
)

Definition at line 986 of file syscallsreal.c.

int _real_semop ( int  semid,
struct sembuf *  sops,
size_t  nsops 
)

Definition at line 991 of file syscallsreal.c.

int _real_semtimedop ( int  semid,
struct sembuf *  sops,
size_t  nsops,
const struct timespec *  timeout 
)

Definition at line 996 of file syscallsreal.c.

int _real_setsockopt ( int  s,
int  level,
int  optname,
const void *  optval,
socklen_t  optlen 
)

call the libc version of this function via dlopen/dlsym

Definition at line 167 of file nosyscallsreal.c.

void* _real_shmat ( int  shmid,
const void *  shmaddr,
int  shmflg 
)

Definition at line 424 of file nosyscallsreal.c.

int _real_shmctl ( int  shmid,
int  cmd,
struct shmid_ds *  buf 
)

Definition at line 432 of file nosyscallsreal.c.

int _real_shmdt ( const void *  shmaddr)

Definition at line 428 of file nosyscallsreal.c.

int _real_shmget ( int  key,
size_t  size,
int  shmflg 
)

Definition at line 949 of file syscallsreal.c.

int _real_sigaction ( int  signum,
const struct sigaction act,
struct sigaction oldact 
)

Definition at line 718 of file syscallsreal.c.

int _real_sigblock ( int  mask)

Definition at line 731 of file syscallsreal.c.

int _real_siggetmask ( void  )

Definition at line 739 of file syscallsreal.c.

int _real_sighold ( int  sig)

Definition at line 767 of file syscallsreal.c.

int _real_sigignore ( int  sig)

Definition at line 771 of file syscallsreal.c.

sighandler_t _real_signal ( int  signum,
sighandler_t  handler 
)

Definition at line 714 of file syscallsreal.c.

int _real_sigpause ( int  sig)

Definition at line 780 of file syscallsreal.c.

int _real_sigprocmask ( int  how,
const sigset_t *  set,
sigset_t *  oldset 
)

Definition at line 743 of file syscallsreal.c.

int _real_sigrelse ( int  sig)

Definition at line 784 of file syscallsreal.c.

sighandler_t _real_sigset ( int  sig,
sighandler_t  disp 
)

Definition at line 762 of file syscallsreal.c.

int _real_sigsetmask ( int  mask)

Definition at line 735 of file syscallsreal.c.

int _real_sigsuspend ( const sigset_t *  mask)

Definition at line 758 of file syscallsreal.c.

int _real_sigtimedwait ( const sigset_t *  set,
siginfo_t *  info,
const struct timespec *  timeout 
)

Definition at line 797 of file syscallsreal.c.

int _real_sigvec ( int  sig,
const struct sigvec vec,
struct sigvec ovec 
)

Definition at line 724 of file syscallsreal.c.

int _real_sigwait ( const sigset_t *  set,
int *  sig 
)

Definition at line 789 of file syscallsreal.c.

int _real_sigwaitinfo ( const sigset_t *  set,
siginfo_t *  info 
)

Definition at line 793 of file syscallsreal.c.

int _real_socket ( int  domain,
int  type,
int  protocol 
)

call the libc version of this function via dlopen/dlsym

Definition at line 137 of file nosyscallsreal.c.

int _real_socketpair ( int  d,
int  type,
int  protocol,
int  sv[2] 
)

Definition at line 246 of file nosyscallsreal.c.

long _real_syscall ( long  sys_num,
  ... 
)

Definition at line 361 of file nosyscallsreal.c.

int _real_system ( const char *  cmd)

Definition at line 195 of file nosyscallsreal.c.

int _real_ttyname_r ( int  fd,
char *  buf,
size_t  buflen 
)

Definition at line 689 of file syscallsreal.c.

int _real_unlink ( const char *  pathname)
pid_t _real_wait4 ( pid_t  pid,
__WAIT_STATUS  status,
int  options,
struct rusage *  rusage 
)

Definition at line 329 of file nosyscallsreal.c.

int _real_waitid ( idtype_t  idtype,
id_t  id,
siginfo_t *  infop,
int  options 
)

Definition at line 321 of file nosyscallsreal.c.

ssize_t _real_write ( int  fd,
const void *  buf,
size_t  count 
)

Definition at line 127 of file nosyscallsreal.c.

int _real_xstat ( int  vers,
const char *  path,
struct stat *  buf 
)

Definition at line 394 of file pid_syscallsreal.c.

int _real_xstat64 ( int  vers,
const char *  path,
struct stat64 *  buf 
)

Definition at line 398 of file pid_syscallsreal.c.

LIB_PRIVATE pid_t dmtcp_gettid ( )

Definition at line 378 of file nosyscallsreal.c.

LIB_PRIVATE int dmtcp_tgkill ( int  tgid,
int  tid,
int  sig 
)

Definition at line 384 of file nosyscallsreal.c.

LIB_PRIVATE int dmtcp_tkill ( int  tid,
int  sig 
)

Definition at line 381 of file nosyscallsreal.c.

LIB_PRIVATE void dmtcpResetPidPpid ( )

Definition at line 59 of file pidwrappers.cpp.

LIB_PRIVATE void dmtcpResetTid ( pid_t  tid)

Definition at line 111 of file pidwrappers.cpp.

void initialize_libc_wrappers ( )

Definition at line 252 of file syscallsreal.c.

void initialize_libpthread_wrappers ( )

Definition at line 297 of file syscallsreal.c.

Variable Documentation

int dmtcp_wrappers_initializing

Definition at line 42 of file dmtcpworker.cpp.

LIB_PRIVATE __thread int thread_performing_dlopen_dlsym