mirror of
https://github.com/postgres/postgres.git
synced 2025-09-05 02:22:28 +03: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:
@@ -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);
|
||||
|
Reference in New Issue
Block a user