亚洲欧美第一页_禁久久精品乱码_粉嫩av一区二区三区免费野_久草精品视频

? 歡迎來到蟲蟲下載站! | ?? 資源下載 ?? 資源專輯 ?? 關于我們
? 蟲蟲下載站

?? clntproc.c

?? Linux中關于遠程文件鎖定的支持的源代碼
?? C
?? 第 1 頁 / 共 2 頁
字號:
/* * linux/fs/lockd/clntproc.c * * RPC procedures for the client side NLM implementation * * Copyright (C) 1996, Olaf Kirch <okir@monad.swb.de> */#include <linux/module.h>#include <linux/types.h>#include <linux/errno.h>#include <linux/fs.h>#include <linux/nfs_fs.h>#include <linux/utsname.h>#include <linux/freezer.h>#include <linux/sunrpc/clnt.h>#include <linux/sunrpc/svc.h>#include <linux/lockd/lockd.h>#define NLMDBG_FACILITY		NLMDBG_CLIENT#define NLMCLNT_GRACE_WAIT	(5*HZ)#define NLMCLNT_POLL_TIMEOUT	(30*HZ)#define NLMCLNT_MAX_RETRIES	3static int	nlmclnt_test(struct nlm_rqst *, struct file_lock *);static int	nlmclnt_lock(struct nlm_rqst *, struct file_lock *);static int	nlmclnt_unlock(struct nlm_rqst *, struct file_lock *);static int	nlm_stat_to_errno(__be32 stat);static void	nlmclnt_locks_init_private(struct file_lock *fl, struct nlm_host *host);static int	nlmclnt_cancel(struct nlm_host *, int , struct file_lock *);static const struct rpc_call_ops nlmclnt_unlock_ops;static const struct rpc_call_ops nlmclnt_cancel_ops;/* * Cookie counter for NLM requests */static atomic_t	nlm_cookie = ATOMIC_INIT(0x1234);void nlmclnt_next_cookie(struct nlm_cookie *c){	u32	cookie = atomic_inc_return(&nlm_cookie);	memcpy(c->data, &cookie, 4);	c->len=4;}static struct nlm_lockowner *nlm_get_lockowner(struct nlm_lockowner *lockowner){	atomic_inc(&lockowner->count);	return lockowner;}static void nlm_put_lockowner(struct nlm_lockowner *lockowner){	if (!atomic_dec_and_lock(&lockowner->count, &lockowner->host->h_lock))		return;	list_del(&lockowner->list);	spin_unlock(&lockowner->host->h_lock);	nlm_release_host(lockowner->host);	kfree(lockowner);}static inline int nlm_pidbusy(struct nlm_host *host, uint32_t pid){	struct nlm_lockowner *lockowner;	list_for_each_entry(lockowner, &host->h_lockowners, list) {		if (lockowner->pid == pid)			return -EBUSY;	}	return 0;}static inline uint32_t __nlm_alloc_pid(struct nlm_host *host){	uint32_t res;	do {		res = host->h_pidcount++;	} while (nlm_pidbusy(host, res) < 0);	return res;}static struct nlm_lockowner *__nlm_find_lockowner(struct nlm_host *host, fl_owner_t owner){	struct nlm_lockowner *lockowner;	list_for_each_entry(lockowner, &host->h_lockowners, list) {		if (lockowner->owner != owner)			continue;		return nlm_get_lockowner(lockowner);	}	return NULL;}static struct nlm_lockowner *nlm_find_lockowner(struct nlm_host *host, fl_owner_t owner){	struct nlm_lockowner *res, *new = NULL;	spin_lock(&host->h_lock);	res = __nlm_find_lockowner(host, owner);	if (res == NULL) {		spin_unlock(&host->h_lock);		new = kmalloc(sizeof(*new), GFP_KERNEL);		spin_lock(&host->h_lock);		res = __nlm_find_lockowner(host, owner);		if (res == NULL && new != NULL) {			res = new;			atomic_set(&new->count, 1);			new->owner = owner;			new->pid = __nlm_alloc_pid(host);			new->host = nlm_get_host(host);			list_add(&new->list, &host->h_lockowners);			new = NULL;		}	}	spin_unlock(&host->h_lock);	kfree(new);	return res;}/* * Initialize arguments for TEST/LOCK/UNLOCK/CANCEL calls */static void nlmclnt_setlockargs(struct nlm_rqst *req, struct file_lock *fl){	struct nlm_args	*argp = &req->a_args;	struct nlm_lock	*lock = &argp->lock;	nlmclnt_next_cookie(&argp->cookie);	argp->state   = nsm_local_state;	memcpy(&lock->fh, NFS_FH(fl->fl_file->f_path.dentry->d_inode), sizeof(struct nfs_fh));	lock->caller  = utsname()->nodename;	lock->oh.data = req->a_owner;	lock->oh.len  = snprintf(req->a_owner, sizeof(req->a_owner), "%u@%s",				(unsigned int)fl->fl_u.nfs_fl.owner->pid,				utsname()->nodename);	lock->svid = fl->fl_u.nfs_fl.owner->pid;	lock->fl.fl_start = fl->fl_start;	lock->fl.fl_end = fl->fl_end;	lock->fl.fl_type = fl->fl_type;}static void nlmclnt_release_lockargs(struct nlm_rqst *req){	BUG_ON(req->a_args.lock.fl.fl_ops != NULL);}/** * nlmclnt_proc - Perform a single client-side lock request * @host: address of a valid nlm_host context representing the NLM server * @cmd: fcntl-style file lock operation to perform * @fl: address of arguments for the lock operation * */int nlmclnt_proc(struct nlm_host *host, int cmd, struct file_lock *fl){	struct nlm_rqst		*call;	int			status;	nlm_get_host(host);	call = nlm_alloc_call(host);	if (call == NULL)		return -ENOMEM;	nlmclnt_locks_init_private(fl, host);	/* Set up the argument struct */	nlmclnt_setlockargs(call, fl);	if (IS_SETLK(cmd) || IS_SETLKW(cmd)) {		if (fl->fl_type != F_UNLCK) {			call->a_args.block = IS_SETLKW(cmd) ? 1 : 0;			status = nlmclnt_lock(call, fl);		} else			status = nlmclnt_unlock(call, fl);	} else if (IS_GETLK(cmd))		status = nlmclnt_test(call, fl);	else		status = -EINVAL;	fl->fl_ops->fl_release_private(fl);	fl->fl_ops = NULL;	dprintk("lockd: clnt proc returns %d\n", status);	return status;}EXPORT_SYMBOL_GPL(nlmclnt_proc);/* * Allocate an NLM RPC call struct * * Note: the caller must hold a reference to host. In case of failure, * this reference will be released. */struct nlm_rqst *nlm_alloc_call(struct nlm_host *host){	struct nlm_rqst	*call;	for(;;) {		call = kzalloc(sizeof(*call), GFP_KERNEL);		if (call != NULL) {			atomic_set(&call->a_count, 1);			locks_init_lock(&call->a_args.lock.fl);			locks_init_lock(&call->a_res.lock.fl);			call->a_host = host;			return call;		}		if (signalled())			break;		printk("nlm_alloc_call: failed, waiting for memory\n");		schedule_timeout_interruptible(5*HZ);	}	nlm_release_host(host);	return NULL;}void nlm_release_call(struct nlm_rqst *call){	if (!atomic_dec_and_test(&call->a_count))		return;	nlm_release_host(call->a_host);	nlmclnt_release_lockargs(call);	kfree(call);}static void nlmclnt_rpc_release(void *data){	lock_kernel();	nlm_release_call(data);	unlock_kernel();}static int nlm_wait_on_grace(wait_queue_head_t *queue){	DEFINE_WAIT(wait);	int status = -EINTR;	prepare_to_wait(queue, &wait, TASK_INTERRUPTIBLE);	if (!signalled ()) {		schedule_timeout(NLMCLNT_GRACE_WAIT);		try_to_freeze();		if (!signalled ())			status = 0;	}	finish_wait(queue, &wait);	return status;}/* * Generic NLM call */static intnlmclnt_call(struct rpc_cred *cred, struct nlm_rqst *req, u32 proc){	struct nlm_host	*host = req->a_host;	struct rpc_clnt	*clnt;	struct nlm_args	*argp = &req->a_args;	struct nlm_res	*resp = &req->a_res;	struct rpc_message msg = {		.rpc_argp	= argp,		.rpc_resp	= resp,		.rpc_cred	= cred,	};	int		status;	dprintk("lockd: call procedure %d on %s\n",			(int)proc, host->h_name);	do {		if (host->h_reclaiming && !argp->reclaim)			goto in_grace_period;		/* If we have no RPC client yet, create one. */		if ((clnt = nlm_bind_host(host)) == NULL)			return -ENOLCK;		msg.rpc_proc = &clnt->cl_procinfo[proc];		/* Perform the RPC call. If an error occurs, try again */		if ((status = rpc_call_sync(clnt, &msg, 0)) < 0) {			dprintk("lockd: rpc_call returned error %d\n", -status);			switch (status) {			case -EPROTONOSUPPORT:				status = -EINVAL;				break;			case -ECONNREFUSED:			case -ETIMEDOUT:			case -ENOTCONN:				nlm_rebind_host(host);				status = -EAGAIN;				break;			case -ERESTARTSYS:				return signalled () ? -EINTR : status;			default:				break;			}			break;		} else		if (resp->status == nlm_lck_denied_grace_period) {			dprintk("lockd: server in grace period\n");			if (argp->reclaim) {				printk(KERN_WARNING				     "lockd: spurious grace period reject?!\n");				return -ENOLCK;			}		} else {			if (!argp->reclaim) {				/* We appear to be out of the grace period */				wake_up_all(&host->h_gracewait);			}			dprintk("lockd: server returns status %d\n", resp->status);			return 0;	/* Okay, call complete */		}in_grace_period:		/*		 * The server has rebooted and appears to be in the grace		 * period during which locks are only allowed to be		 * reclaimed.		 * We can only back off and try again later.		 */		status = nlm_wait_on_grace(&host->h_gracewait);	} while (status == 0);	return status;}/* * Generic NLM call, async version. */static struct rpc_task *__nlm_async_call(struct nlm_rqst *req, u32 proc, struct rpc_message *msg, const struct rpc_call_ops *tk_ops){	struct nlm_host	*host = req->a_host;	struct rpc_clnt	*clnt;	struct rpc_task_setup task_setup_data = {		.rpc_message = msg,		.callback_ops = tk_ops,		.callback_data = req,		.flags = RPC_TASK_ASYNC,	};	dprintk("lockd: call procedure %d on %s (async)\n",			(int)proc, host->h_name);	/* If we have no RPC client yet, create one. */	clnt = nlm_bind_host(host);	if (clnt == NULL)		goto out_err;	msg->rpc_proc = &clnt->cl_procinfo[proc];	task_setup_data.rpc_client = clnt;        /* bootstrap and kick off the async RPC call */	return rpc_run_task(&task_setup_data);out_err:	tk_ops->rpc_release(req);	return ERR_PTR(-ENOLCK);}static int nlm_do_async_call(struct nlm_rqst *req, u32 proc, struct rpc_message *msg, const struct rpc_call_ops *tk_ops){	struct rpc_task *task;	task = __nlm_async_call(req, proc, msg, tk_ops);	if (IS_ERR(task))		return PTR_ERR(task);	rpc_put_task(task);	return 0;}/* * NLM asynchronous call. */int nlm_async_call(struct nlm_rqst *req, u32 proc, const struct rpc_call_ops *tk_ops){	struct rpc_message msg = {		.rpc_argp	= &req->a_args,		.rpc_resp	= &req->a_res,	};	return nlm_do_async_call(req, proc, &msg, tk_ops);}int nlm_async_reply(struct nlm_rqst *req, u32 proc, const struct rpc_call_ops *tk_ops){	struct rpc_message msg = {		.rpc_argp	= &req->a_res,	};	return nlm_do_async_call(req, proc, &msg, tk_ops);}/* * NLM client asynchronous call. * * Note that although the calls are asynchronous, and are therefore *      guaranteed to complete, we still always attempt to wait for *      completion in order to be able to correctly track the lock *      state. */static int nlmclnt_async_call(struct rpc_cred *cred, struct nlm_rqst *req, u32 proc, const struct rpc_call_ops *tk_ops){	struct rpc_message msg = {		.rpc_argp	= &req->a_args,		.rpc_resp	= &req->a_res,		.rpc_cred	= cred,	};	struct rpc_task *task;	int err;	task = __nlm_async_call(req, proc, &msg, tk_ops);	if (IS_ERR(task))		return PTR_ERR(task);	err = rpc_wait_for_completion_task(task);	rpc_put_task(task);	return err;}/* * TEST for the presence of a conflicting lock */static intnlmclnt_test(struct nlm_rqst *req, struct file_lock *fl){	int	status;	status = nlmclnt_call(nfs_file_cred(fl->fl_file), req, NLMPROC_TEST);	if (status < 0)		goto out;

?? 快捷鍵說明

復制代碼 Ctrl + C
搜索代碼 Ctrl + F
全屏模式 F11
切換主題 Ctrl + Shift + D
顯示快捷鍵 ?
增大字號 Ctrl + =
減小字號 Ctrl + -
亚洲欧美第一页_禁久久精品乱码_粉嫩av一区二区三区免费野_久草精品视频
精品国产亚洲在线| 国产精品亚洲一区二区三区在线| 韩国女主播一区| 欧美日韩国产天堂| 综合欧美一区二区三区| 国产精品自拍一区| 日韩精品影音先锋| 中文字幕在线不卡视频| 国产老肥熟一区二区三区| 日韩欧美自拍偷拍| 久久精品国产澳门| 日韩欧美三级在线| 日韩精品91亚洲二区在线观看| 欧美精品久久一区二区三区| 一区二区三区在线视频免费观看| 波多野结衣在线一区| 欧美国产综合一区二区| 国产成人亚洲精品狼色在线| 丝瓜av网站精品一区二区| 久久久久久久久久看片| 日韩一级黄色大片| 国产成人免费视频网站 | 97se狠狠狠综合亚洲狠狠| 国产精品久久久久久久久免费桃花| 91视频在线观看| 日本免费在线视频不卡一不卡二| 在线成人av网站| 国产高清亚洲一区| 欧美xxxxx牲另类人与| 极品少妇xxxx精品少妇| 精品少妇一区二区三区日产乱码| 美女在线一区二区| 亚洲精品一区二区三区99 | 欧美性色黄大片手机版| 一区二区成人在线观看| 欧洲视频一区二区| 视频一区欧美日韩| 日韩精品一区二区三区在线播放| 国内偷窥港台综合视频在线播放| 26uuu国产电影一区二区| 午夜电影网亚洲视频| proumb性欧美在线观看| 亚洲综合区在线| 欧美精品在线视频| 免费高清不卡av| 欧美国产日韩一二三区| 91视频你懂的| 天天操天天色综合| 久久精品视频免费| 99久久精品国产网站| 一区二区国产盗摄色噜噜| 在线播放视频一区| 国产一区二区三区免费| 欧美激情在线观看视频免费| 在线亚洲免费视频| 久久精品国产成人一区二区三区| 久久久久久久久久久久久夜| 成人午夜av影视| 亚洲一区免费在线观看| 色国产精品一区在线观看| 久久精品国产免费看久久精品| 国产欧美一区二区精品秋霞影院| av在线不卡免费看| 久久精品国产在热久久| 国产精品乱码妇女bbbb| 欧洲国内综合视频| 国产精品亚洲综合一区在线观看| 亚洲婷婷综合色高清在线| 51精品秘密在线观看| av在线不卡观看免费观看| 亚洲国产精品视频| 26uuu国产在线精品一区二区| 色国产综合视频| 国产在线看一区| 亚洲另类春色校园小说| 欧美精品一区二区三区很污很色的 | 亚洲六月丁香色婷婷综合久久 | 91伊人久久大香线蕉| 亚洲国产精品自拍| 欧美一区在线视频| 91在线观看污| 蜜桃在线一区二区三区| 国产女人水真多18毛片18精品视频 | 欧美综合亚洲图片综合区| 日韩成人免费电影| 中文字幕一区三区| 欧美一区二区三区在线视频| 成人少妇影院yyyy| 午夜伦理一区二区| 亚洲女同一区二区| 精品区一区二区| 91啪亚洲精品| 国产91精品露脸国语对白| 五月综合激情网| 一区在线观看视频| 精品久久久久久久久久久久久久久| heyzo一本久久综合| 九九国产精品视频| 亚洲自拍偷拍综合| 国产精品久久久久毛片软件| 日韩一级高清毛片| 91久久精品网| 五月开心婷婷久久| 一级精品视频在线观看宜春院| 欧美va天堂va视频va在线| 色婷婷久久综合| 福利一区二区在线| 免费人成精品欧美精品| 一区二区三区精品视频在线| 国产精品欧美极品| 精品国产免费一区二区三区香蕉| 91国偷自产一区二区使用方法| 不卡一区二区中文字幕| 蜜臀99久久精品久久久久久软件 | 日韩一区二区三区视频在线| 成人黄页毛片网站| 国产成人av一区二区| 美女一区二区久久| 亚洲一区欧美一区| 亚洲综合小说图片| 中文字幕在线不卡视频| 久久久精品国产99久久精品芒果| 久久亚洲免费视频| 日韩欧美一区二区在线视频| 欧美性猛交一区二区三区精品| www.爱久久.com| 国产精品亚洲第一区在线暖暖韩国| 日本免费新一区视频| 奇米影视7777精品一区二区| 性做久久久久久免费观看| 一区二区三区小说| 国产肉丝袜一区二区| 26uuu国产一区二区三区| 日韩丝袜情趣美女图片| 99精品视频在线观看| 99久久精品国产导航| 国产成人av网站| 韩国在线一区二区| 韩国av一区二区三区四区| 久久er精品视频| 久久99久久久欧美国产| 日韩精品电影一区亚洲| 日韩av网站在线观看| 日韩精品一二三| 亚洲一区二区视频在线观看| 亚洲18色成人| 亚洲成av人片在www色猫咪| 亚洲女人****多毛耸耸8| 亚洲欧美乱综合| 亚洲人妖av一区二区| 亚洲国产精品久久久久秋霞影院 | 婷婷六月综合网| 香蕉加勒比综合久久| 同产精品九九九| 青青草原综合久久大伊人精品| 免费成人美女在线观看| 国产一区二区三区美女| 成人一区二区三区中文字幕| 成人免费电影视频| 日韩午夜中文字幕| 欧美午夜片在线观看| 91.com视频| 2021中文字幕一区亚洲| 国产精品污网站| 亚洲精品你懂的| 天天综合日日夜夜精品| 九九**精品视频免费播放| 成人午夜免费av| 精品婷婷伊人一区三区三| 精品国产一区二区精华| 欧美激情中文不卡| 亚洲成a人片在线观看中文| 久久99久久精品欧美| 成人黄色777网| 日本韩国视频一区二区| 日韩限制级电影在线观看| 久久久电影一区二区三区| 亚洲激情图片一区| 久久se精品一区二区| 91视频精品在这里| 日韩欧美黄色影院| 亚洲欧美怡红院| 老司机免费视频一区二区| 99久久er热在这里只有精品15| 欧美久久久影院| 国产精品久久久久精k8| 日韩电影一区二区三区四区| 成人黄色国产精品网站大全在线免费观看| 日本韩国欧美一区| 久久久五月婷婷| 亚洲高清免费观看高清完整版在线观看| 九色综合国产一区二区三区| 91福利视频网站| 久久亚洲精精品中文字幕早川悠里| 一区二区成人在线观看| 国产成人一级电影| 在线综合亚洲欧美在线视频| 国产精品麻豆久久久| 蜜臀久久久99精品久久久久久| 99国产精品国产精品毛片|