mirror of
https://git.postgresql.org/git/postgresql.git
synced 2024-11-27 07:21:09 +08:00
Remove dead getpwuid_r replacement code.
getpwuid_r is in SUSv2 and all targeted Unix systems have it. We don't use it for Windows. Reviewed-by: Tom Lane <tgl@sss.pgh.pa.us> Reviewed-by: Greg Stark <stark@mit.edu> Reviewed-by: Robert Haas <robertmhaas@gmail.com> Discussion: https://postgr.es/m/CA+hUKGJ3LHeP9w5Fgzdr4G8AnEtJ=z=p6hGDEm4qYGEUX5B6fQ@mail.gmail.com
This commit is contained in:
parent
fb12becdfb
commit
e757cdd6ad
2
configure
vendored
2
configure
vendored
@ -11751,7 +11751,7 @@ fi
|
||||
|
||||
|
||||
|
||||
for ac_func in strerror_r getpwuid_r gethostbyname_r
|
||||
for ac_func in strerror_r gethostbyname_r
|
||||
do :
|
||||
as_ac_var=`$as_echo "ac_cv_func_$ac_func" | $as_tr_sh`
|
||||
ac_fn_c_check_func "$LINENO" "$ac_func" "$as_ac_var"
|
||||
|
@ -1214,7 +1214,7 @@ LIBS="$LIBS $PTHREAD_LIBS"
|
||||
AC_CHECK_HEADER(pthread.h, [], [AC_MSG_ERROR([
|
||||
pthread.h not found; use --disable-thread-safety to disable thread safety])])
|
||||
|
||||
AC_CHECK_FUNCS([strerror_r getpwuid_r gethostbyname_r])
|
||||
AC_CHECK_FUNCS([strerror_r gethostbyname_r])
|
||||
|
||||
# Do test here with the proper thread flags
|
||||
PGAC_FUNC_STRERROR_R_INT
|
||||
|
@ -240,9 +240,6 @@
|
||||
/* Define to 1 if you have the `getpeerucred' function. */
|
||||
#undef HAVE_GETPEERUCRED
|
||||
|
||||
/* Define to 1 if you have the `getpwuid_r' function. */
|
||||
#undef HAVE_GETPWUID_R
|
||||
|
||||
/* Define to 1 if you have the `getrlimit' function. */
|
||||
#undef HAVE_GETRLIMIT
|
||||
|
||||
|
@ -18,62 +18,12 @@
|
||||
|
||||
|
||||
/*
|
||||
* Threading sometimes requires specially-named versions of functions
|
||||
* that return data in static buffers, like strerror_r() instead of
|
||||
* strerror(). Other operating systems use pthread_setspecific()
|
||||
* and pthread_getspecific() internally to allow standard library
|
||||
* functions to return static data to threaded applications. And some
|
||||
* operating systems have neither.
|
||||
*
|
||||
* Additional confusion exists because many operating systems that
|
||||
* use pthread_setspecific/pthread_getspecific() also have *_r versions
|
||||
* of standard library functions for compatibility with operating systems
|
||||
* that require them. However, internally, these *_r functions merely
|
||||
* call the thread-safe standard library functions.
|
||||
*
|
||||
* For example, BSD/OS 4.3 uses Bind 8.2.3 for getpwuid(). Internally,
|
||||
* getpwuid() calls pthread_setspecific/pthread_getspecific() to return
|
||||
* static data to the caller in a thread-safe manner. However, BSD/OS
|
||||
* also has getpwuid_r(), which merely calls getpwuid() and shifts
|
||||
* around the arguments to match the getpwuid_r() function declaration.
|
||||
* Therefore, while BSD/OS has getpwuid_r(), it isn't required. It also
|
||||
* doesn't have strerror_r(), so we can't fall back to only using *_r
|
||||
* functions for threaded programs.
|
||||
*
|
||||
* The current setup is to try threading in this order:
|
||||
*
|
||||
* use *_r function names if they exit
|
||||
* (*_THREADSAFE=yes)
|
||||
* use non-*_r functions if they are thread-safe
|
||||
* Historically, the code in this module had to deal with operating systems
|
||||
* that lacked getpwuid_r().
|
||||
*/
|
||||
|
||||
#ifndef WIN32
|
||||
|
||||
/*
|
||||
* Wrapper around getpwuid() or getpwuid_r() to mimic POSIX getpwuid_r()
|
||||
* behaviour, if that function is not available or required.
|
||||
*
|
||||
* Per POSIX, the possible cases are:
|
||||
* success: returns zero, *result is non-NULL
|
||||
* uid not found: returns zero, *result is NULL
|
||||
* error during lookup: returns an errno code, *result is NULL
|
||||
* (caller should *not* assume that the errno variable is set)
|
||||
*/
|
||||
static int
|
||||
pqGetpwuid(uid_t uid, struct passwd *resultbuf, char *buffer,
|
||||
size_t buflen, struct passwd **result)
|
||||
{
|
||||
#if defined(FRONTEND) && defined(ENABLE_THREAD_SAFETY) && defined(HAVE_GETPWUID_R)
|
||||
return getpwuid_r(uid, resultbuf, buffer, buflen, result);
|
||||
#else
|
||||
/* no getpwuid_r() available, just use getpwuid() */
|
||||
errno = 0;
|
||||
*result = getpwuid(uid);
|
||||
/* paranoia: ensure we return zero on success */
|
||||
return (*result == NULL) ? errno : 0;
|
||||
#endif
|
||||
}
|
||||
|
||||
/*
|
||||
* pg_get_user_name - get the name of the user with the given ID
|
||||
*
|
||||
@ -89,7 +39,7 @@ pg_get_user_name(uid_t user_id, char *buffer, size_t buflen)
|
||||
struct passwd *pw = NULL;
|
||||
int pwerr;
|
||||
|
||||
pwerr = pqGetpwuid(user_id, &pwdstr, pwdbuf, sizeof(pwdbuf), &pw);
|
||||
pwerr = getpwuid_r(user_id, &pwdstr, pwdbuf, sizeof(pwdbuf), &pw);
|
||||
if (pw != NULL)
|
||||
{
|
||||
strlcpy(buffer, pw->pw_name, buflen);
|
||||
@ -125,7 +75,7 @@ pg_get_user_home_dir(uid_t user_id, char *buffer, size_t buflen)
|
||||
struct passwd *pw = NULL;
|
||||
int pwerr;
|
||||
|
||||
pwerr = pqGetpwuid(user_id, &pwdstr, pwdbuf, sizeof(pwdbuf), &pw);
|
||||
pwerr = getpwuid_r(user_id, &pwdstr, pwdbuf, sizeof(pwdbuf), &pw);
|
||||
if (pw != NULL)
|
||||
{
|
||||
strlcpy(buffer, pw->pw_dir, buflen);
|
||||
|
@ -274,7 +274,6 @@ sub GenerateFiles
|
||||
HAVE_GETOPT_LONG => undef,
|
||||
HAVE_GETPEEREID => undef,
|
||||
HAVE_GETPEERUCRED => undef,
|
||||
HAVE_GETPWUID_R => undef,
|
||||
HAVE_GETRLIMIT => undef,
|
||||
HAVE_GETTIMEOFDAY => undef,
|
||||
HAVE_GSSAPI_GSSAPI_H => undef,
|
||||
|
Loading…
Reference in New Issue
Block a user