KEMBAR78
15 Synchronization | PDF | Computer Programming | Computer Engineering
0% found this document useful (0 votes)
87 views120 pages

15 Synchronization

Synchronization is challenging for operating system code due to race conditions that can occur when multiple threads access shared resources concurrently. Race conditions happen when the execution order of threads cannot be predicted, so the final value of a shared variable may depend on its scheduling. Solutions to problems like critical sections require mechanisms like spinlocks and mutexes that provide atomic access to shared resources using hardware instructions like test-and-set or swap. These locks allow only one thread at a time to enter the critical section to access shared data in a mutually exclusive and predictable way.
Copyright
© © All Rights Reserved
We take content rights seriously. If you suspect this is your content, claim it here.
Available Formats
Download as PDF, TXT or read online on Scribd
0% found this document useful (0 votes)
87 views120 pages

15 Synchronization

Synchronization is challenging for operating system code due to race conditions that can occur when multiple threads access shared resources concurrently. Race conditions happen when the execution order of threads cannot be predicted, so the final value of a shared variable may depend on its scheduling. Solutions to problems like critical sections require mechanisms like spinlocks and mutexes that provide atomic access to shared resources using hardware instructions like test-and-set or swap. These locks allow only one thread at a time to enter the critical section to access shared data in a mutually exclusive and predictable way.
Copyright
© © All Rights Reserved
We take content rights seriously. If you suspect this is your content, claim it here.
Available Formats
Download as PDF, TXT or read online on Scribd
You are on page 1/ 120

Synchronization

My formulation

OS = data structurs + synchronization

Synchronization problems make writing OS
code challenging

Demand exceptional coding skills
Race problem
long c = 0, c1 = 0, c2 = 0, run = 1; int main() {
void *thread1(void *arg) { pthread_t th1, th2;
while(run == 1) { pthread_create(&th1, NULL, thread1,
c++; NULL);
c1++; pthread_create(&th2, NULL, thread2,
} NULL);
} //fprintf(stdout, "Ending main\n");
void *thread2(void *arg) { sleep(2);
while(run == 1) { run = 0;
c++; fprintf(stdout, "c = %ld c1+c2 = %ld
c2++; c1 = %ld c2 = %ld \n", c, c1+c2, c1, c2);
} fflush(stdout);
} }
Race problem

On earlier slide

Value of c should be equal to c1 + c2, but it is not!

Why?

There is a “race” between thread1 and thread2 for
updating the variable c

thread1 and thread2 may get scheduled in any
order and interrupted any point in time

The changes to c are not atomic!

What does that mean?
Race problem

C++, when converted to assembly code, could be
mov c, r1
add r1, 1
mov r1, c

Now following sequence of instructions is possible among
thread1 and thread2
thread1: mov c, r1
thread2: mov c, r1
thread1: add r1, 1
thread1: mov r1, c
thread2: add r1, 1
thread2: mov r1, c

What will be value in c, if initially c was, say 5?

It will be 6, when it is expected to be 7. Other variations also possible.
Races: reasons

Interruptible kernel

If entry to kernel code does not disable interrupts, then modifications
to any kernel data structure can be left incomplete

This introduces concurrency

Multiprocessor systems

On SMP systems: memory is shared, kernel and process code run on
all processors

Same variable can be updated parallely (not concurrently)

What about non-interruptible kernel on multiprocessor
systems?

What about non-interruptible kernel on uniprocessor systems?
Critical Section Problem

Consider system of n processes {p0, p1, … pn-1}

Each process has critical section segment of code

Process may be changing common variables, updating table,
writing file, etc

When one process in critical section, no other may be in its
critical section

Critical section problem is to design protocol to solve this

Each process must ask permission to enter critical section
in entry section, may follow critical section with exit
section, then remainder section

Especially challenging with preemptive kernels
Critical Section problem
Expected solution characteristics

1. Mutual Exclusion

If process Pi is executing in its critical section, then no other
processes can be executing in their critical sections

2. Progress

If no process is executing in its critical section and there exist
some processes that wish to enter their critical section, then the
selection of the processes that will enter the critical section next
cannot be postponed indefinitely

3. Bounded Waiting

A bound must exist on the number of times that other processes
are allowed to enter their critical sections after a process has
made a request to enter its critical section and before that
request is granted

Assume that each process executes at a nonzero speed

No assumption concerning relative speed of the n processes
suggested solution - 1
int flag = 1; 
What’s wrong here?
void *thread1(void *arg) {
while(run == 1) {

Assumes that
while(flag == 0) while(flag ==) ; flag
; =0
flag = 0;
c++;
will be atomic
flag = 1;
c1++;
}
}
suggested solution - 2
int flag = 0; void *thread2(void *arg) {
void *thread1(void *arg) { while(run == 1) {
while(run == 1) { if(!flag)
if(flag)
c++;
c++;
else
else
continue;
continue;
c1++; c2++;
flag = 0; flag = 1;
} }
} }
Peterson’s solution

Two process solution

Assume that the LOAD and STORE instructions are atomic;
that is, cannot be interrupted

The two processes share two variables:
int turn;
Boolean flag[2]

The variable turn indicates whose turn it is to enter the
critical section

The flag array is used to indicate if a process is ready to
enter the critical section. flag[i] = true implies that process Pi
is ready!
Peterson’s solution
do {
flag[i] = TRUE;
turn = j;
while (flag[j] && turn == j)
;
critical section
flag[i] = FALSE;
remainder section
} while (TRUE);

 Provable that
 Mutual exclusion is preserved
 Progress requirement is satisfied
 Bounded-waiting requirement is met
Hardware solution – the one
actually implemented

Many systems provide hardware support for critical section
code

Uniprocessors – could disable interrupts

Currently running code would execute without preemption

Generally too inefficient on multiprocessor systems

Operating systems using this not broadly scalable

Modern machines provide special atomic hardware instructions

Atomic = non-interruptable

Either test memory word and set value

Or swap contents of two memory words

Basically two operations (read/write) done atomically in hardware
Solution using test-and-set
lock =- false; //global
Definition:
do {
while ( TestAndSet (&lock )) boolean TestAndSet (boolean
; // do nothing *target)
// critical section {
lock = FALSE; boolean rv = *target;
// remainder section *target = TRUE;
} while (TRUE); return rv:
}
Solution using swap
lock = false; //global

do {
key = true
while ( key == true))
swap(&lock, &key)
// critical section
lock = FALSE;
// remainder section
} while (TRUE);
Spinlock

A lock implemented to do ‘busy-wait’

Using instructions like T&S or Swap

As shown on earlier slides
spinlock(int *lock){
While(test-and-set(lock))
;

}
spinunlock(lock *lock) {
*lock = false;
}
do {
Bounded wait M.E. with T&S
waiting[i] = TRUE;
key = TRUE;
while (waiting[i] && key)
key = TestAndSet(&lock);
waiting[i] = FALSE;
// critical section
j = (i + 1) % n;
while ((j != i) && !waiting[j])
j = (j + 1) % n;
if (j == i)
lock = FALSE;
else
waiting[j] = FALSE;
// remainder section
} while (TRUE);
Some thumb-rules of spinlocks

Never block a process holding a spinlock !

Typical code:
while(condition)
{ Spin-unlock()
Schedule()
Spin-lock()
}

Hold a spin lock for only a short duration of time

Spinlocks are preferable on multiprocessor systems

Cost of context switch is a concern in case of sleep-wait locks

Short = < 2 context switches
sleep-locks

Spin locks result in busy-wait

CPU cycles wasted by waiting
processes/threads

Solution – threads keep waiting for the lock
to be available

Move therad to wait queue

The thread holding the lock will wake up one of
them
Sleep locks/mutexes
//ignore syntactical issues Block(mutex *m, spinlock *sl) {
typedef struct mutex { spinunlock(sl);
currprocess->state = WAITING
int islocked;
move current process to m->q
int spinlock;
Sched();
waitqueue q;
spinlock(sl);
}mutex;
}
wait(mutex *m) {
release(mutex *m) {
spinlock(m->spinlock);
spinlock(m->spinlock);
while(m->islocked)
m->islocked = 0;
Block(m, m->spinlock)
Some process in m->queue
lk->islocked = 1; =RUNNABLE;
spinunlock(m->spinlock); spinunlock(m->spinlock);
} }
Locks in xv6 code
struct spinlock
// Mutual exclusion lock.
struct spinlock {
uint locked; // Is the lock held?

// For debugging:
char *name; // Name of lock.
struct cpu *cpu; // The cpu holding the lock.
uint pcs[10]; // The call stack (an array of program counters)
// that locked the lock.
};
spinlocks in xv6 code
struct { static struct spinlock idelock;
struct spinlock lock; struct {
struct buf buf[NBUF]; struct spinlock lock;

struct buf head; int use_lock;


struct run *freelist;
} bcache;
} kmem;
struct {
struct log {
struct spinlock lock;
struct spinlock lock;
struct file file[NFILE];
...}
} ftable; struct pipe {
struct { struct spinlock lock;
struct spinlock lock; ...}
struct inode inode[NINODE]; struct {
} icache; struct spinlock lock;
struct sleeplock { struct proc proc[NPROC];
uint locked; // Is the lock held? } ptable;

struct spinlock lk; struct spinlock tickslock;


static inline uint
xchg(volatile uint *addr, uint newval)
{
uint result;
Spinlock on xv6
// The + in "+m" denotes a read-modify-
write operand.
void acquire(struct spinlock *lk)
asm volatile("lock; xchgl %0, %1" :
"+m" (*addr), "=a" (result) :
{
"1" (newval) : pushcli(); // disable interrupts to
"cc"); avoid deadlock.
return result; // The xchg is atomic.
}
while(xchg(&lk->locked, 1) != 0)
struct spinlock {
uint locked; // Is the lock held? ;
//extra debugging code
// For debugging: }
char *name; // Name of lock.
struct cpu *cpu; // The cpu holding the
void release(struct spinlock *lk)
lock. { //extra debugging code
uint pcs[10]; // The call stack (an array
of program counters) that locked the lock. asm volatile("movl $0, %0" :
};
"+m" (lk->locked) : );
popcli();
}
Void acquire(struct spinlock *lk)
{
pushcli(); // disable interrupts to avoid deadlock.
if(holding(lk))
spinlocks
panic("acquire");
......
void pushcli(void)

Pushcli() - disable
{ interrupts on that
int eflags;
processor
eflags = readeflags(); 
One after another
cli();
if(mycpu()->ncli == 0)
many acquire() can
mycpu()->intena = eflags & FL_IF; be called on different
mycpu()->ncli += 1;
spinlocks
}
static inline uint 
Keep a count of them
readeflags(void) in mycpu()->ncli
{
uint eflags;
asm volatile("pushfl; popl %0" : "=r" (eflags));
return eflags;
}
void
release(struct spinlock *lk)
{
...
spinlocks
asm volatile("movl $0, %0" : "+m" (lk-
>locked) : );
popcli();

Popcli()
} 
Restore interrupts if
.
Void popcli(void)
last popcli() call
{ restores ncli to 0 &
if(readeflags()&FL_IF) interrupts were
panic("popcli - interruptible"); enabled before
if(--mycpu()->ncli < 0)
pushcli() was called
panic("popcli");
if(mycpu()->ncli == 0 && mycpu()->intena)
sti();
}
spinlocks

Always disable interrupts while acquiring spinlock

Suppose iderw held the idelock and then got interrupted to run
ideintr.

Ideintr would try to lock idelock, see it was held, and wait for it to be
released.

In this situation, idelock will never be released

Deadlock

General OS rule: if a spin-lock is used by an interrupt handler,
a processor must never hold that lock with interrupts enabled

Xv6 rule: when a processor enters a spin-lock critical section,
xv6 always ensures interrupts are disabled on that processor.
sleeplocks

Sleeplocks don’t spin. They move a process to a
wait-queue if the lock can’t be acquired

XV6 approach to “wait-queues”

Any memory address serves as a “wait channel”

The sleep() and wakeup() functions just use that
address as a ‘condition’

There are no per condition process queues! Just one
global queue of processes used for scheduling, sleep,
wakeup etc. --> Linear search everytime !

costly, but simple
void
sleep(void *chan, struct spinlock *lk)
{
sleep()
struct proc *p = myproc();
.... 
At call must hold lock on the
if(lk != &ptable.lock){
resource on which you are
going to sleep
acquire(&ptable.lock);

since you are going to change
release(lk);
p-> values & call sched(), hold
} ptable.lock if not held
p->chan = chan; 
p->chan = given address
p->state = SLEEPING; remembers on which
sched(); condition the process is
// Reacquire original lock. waiting
if(lk != &ptable.lock){

call to sched() blocks the
process
release(&ptable.lock);
acquire(lk);
}
Calls to sleep() : examples of
“chan” (output from cscope)
0 console.c 7 proc.c wait
consoleread 251 317 sleep(curproc,
sleep(&input.r, &cons.lock); &ptable.lock);
2 ide.c iderw
169 sleep(b, &idelock);
8 sleeplock.c
acquiresleep 28
3 log.c begin_op sleep(lk, &lk->lk);
131 sleep(&log, &log.lock);
6 pipe.c piperead
9 sysproc.c
111 sleep(&p->nread, &p- sys_sleep 74
>lock); sleep(&ticks, &tickslock);
void wakeup(void *chan)
{ Wakeup()
acquire(&ptable.lock);
wakeup1(chan); 
Acquire ptable.lock
release(&ptable.lock);
since you are going to
}
change ptable and p->
static void wakeup1(void *chan) values
{

just linear search in
struct proc *p;
process table for a
process where p-
for(p = ptable.proc; p < >chan is given address
&ptable.proc[NPROC]; p++)
if(p->state == SLEEPING &&

Make it runnable
p->chan == chan)
p->state = RUNNABLE;
}
sleeplock
// Long-term locks for processes
struct sleeplock {
uint locked; // Is the lock held?
struct spinlock lk; // spinlock protecting this sleep lock

// For debugging:
char *name; // Name of lock.
int pid; // Process holding lock
};
Sleeplock acquire and release
void void
acquiresleep(struct sleeplock *lk)
releasesleep(struct sleeplock
{
*lk)
acquire(&lk->lk);
while (lk->locked) { {
/* Abhijit: interrupts are not disabled in acquire(&lk->lk);
sleep !*/
sleep(lk, &lk->lk); lk->locked = 0;
} lk->pid = 0;
lk->locked = 1;
wakeup(lk);
lk->pid = myproc()->pid;
release(&lk->lk); release(&lk->lk);
} }
Where are sleeplocks used?

struct buf 
Just two !

waiting for I/O on
this buffer

struct inode

waiting for I/o to this
inode
Sleeplocks issues

sleep-locks support yielding the processor during their critical
sections.

This property poses a design challenge:

if thread T1 holds lock L1 and has yielded the processor (waiting for some
other condition),

and thread T2 wishes to acquire L1,

we have to ensure that T1 can execute

while T2 is waiting so that T1 can release L1.

T2 can’t use the spin-lock acquire function here: it spins with interrupts
turned off, and that would prevent T1 from running.

To avoid this deadlock, the sleep-lock acquire routine (called
acquiresleep) yields the processor while waiting, and does not
disable interrupts.
Sleep-locks leave interrupts enabled, they cannot be used in
interrupt handlers.
More needs of synchronization

Not only critical section problems

Run processes in a particular order

Allow multiple processes read access, but
only one process write access

Etc.
Semaphore

Synchronization tool that 
Can only be accessed via two
indivisible (atomic) operations
does not require busy
wait (S) {
waiting
while S <= 0

Semaphore S – integer ; // no-op
variable S--;

Two standard operations }
modify S: wait() and signal (S) {
signal() S++;
}

Originally called P() and V()
--> Note this is Signal() on a

Less complicated semaphore, different froms signal
system call
Semaphore for synchronization
 Counting semaphore – integer value can range over an unrestricted domain
 Binary semaphore – integer value can range only between 0
and 1; can be simpler to implement
Also known as mutex locks
 Can implement a counting semaphore S as a binary semaphore
 Provides mutual exclusion
Semaphore mutex; // initialized to 1
do {
wait (mutex);
// Critical Section
signal (mutex);
// remainder section
} while (TRUE)
Semaphore implementation
Wait(sem *s) { 
Left side – expected
while(s <=0) behaviour
block(); // could be ";" 
Both the wait and
s--; signal should be
} atomic.
signal(sem *s) { 
This is the sematics
s++; of the semaphore.
}
Semaphore implementation? - 1
struct semaphore { signal(seamphore *s) {
int val; spinlock(*(s->sl));
spinlock lk; (s->val)++;
};
spinunlock(*(s->sl));
sem_init(semaphore *s, int initval) {
}
s->val = initval;
- suppose 2 processes trying wait.
s->sl = 0;
} val = 1;
wait(semaphore *s) { Th1: spinlock Th2: spinlock-waits
spinlock(&(s->sl)); Th1: while -> false, val-- => 0; spinulock;
while(s->val <=0) Th2: spinlock success; while() -> true, loops;
; Th1: is done with critical section, it calls
(s->val)--; signal. it calls spinlock() -> wait.
spinunlock(&(s->sl)); Who is holding spinlock-> Th2. Itis waiting
} for val > 0. Who can set value > 0 , ans: Th1,
and Th1 is waiting for spinlock which is held
by The2.
circular wait. Deadlock.
None of them will proceed.
Semaphore implementation? - 2
struct semaphore { wait(semaphore *s) {
int val;
spinlock(&(s->sl));
spinlock lk;
};
while(s->val <=0) {
sem_init(semaphore *s, int initval) { spinunlock(&(s->sl));
s->val = initval; spinlock(&(s->sl));
s->sl = 0;
}
}
(s->val)--;
signal(seamphore *s) {
spinlock(*(s->sl)); spinunlock(&(s->sl));
(s->val)++; }
spinunlock(*(s->sl));
Problem: race in spinlock of whille
} loop and signal's spinlock.
Bounded wait not guaranteed.
Spinlocks are not good for a long
wait.
Semaphore implementation? - 3,
idea
struct semaphore { wait(semaphore *s) {
int val; spinlock(&(s->sl));
spinlock lk;
while(s->val <=0) {
};
Block();
sem_init(semaphore *s, int initval) {
s->val = initval; }
s->sl = 0; (s->val)--;
} spinunlock(&(s->sl));
block() { }
put this current process on wait-q; signal(seamphore *s) {
schedule();
spinlock(*(s->sl));
}
(s->val)++;
spinunlock(*(s->sl));
}
Semaphore implementation? - 3a
struct semaphore { wait(semaphore *s) {
int val;
spinlock(&(s->sl));
spinlock lk;
while(s->val <=0) {
list l;
}; spinunlock(&(s->sl));
sem_init(semaphore *s, int initval) { block(s);
s->val = initval; }
s->sl = 0;
(s->val)--;
}
block(semaphore *s) {
spinunlock(&(s->sl));
listappend(s->l, current); }
schedule(); signal(seamphore *s) {
} spinlock(*(s->sl));
problem is that block() will be called
without holding the spinlock and the (s->val)++;
access to the list is not protected. spinunlock(*(s->sl));
Note that - so far we have ignored changes
to signal() }
Semaphore implementation? - 3b
struct semaphore { wait(semaphore *s) {
spinlock(&(s->sl));
int val;
while(s->val <=0) {
spinlock lk; block(s);
list l; }
}; (s->val)--;

sem_init(semaphore *s, int initval) { spinunlock(&(s->sl));


}
s->val = initval;
signal(seamphore *s) {
s->sl = 0; spinlock(*(s->sl));
} (s->val)++;
block(semaphore *s) { x = dequeue(s->sl) and enqueue(readyq, x);
spinunlock(*(s->sl));
listappend(s->l, current);
}
spinunlock(&(s->sl)); Problem: after a blocked process comes out
schedule(); of the block, it does not hold the spinlock and
it's goinng to change the s->sl;
}
Semaphore implementation? - 3c
struct semaphore { wait(semaphore *s) {
spinlock(&(s->sl)); // A
int val;
while(s->val <=0) {
spinlock lk; block(s);
list l; spinlock(&(s->sl)); // B
}; }

sem_init(semaphore *s, int initval) { (s->val)--;


spinunlock(&(s->sl));
s->val = initval;
}
s->sl = 0; signal(seamphore *s) {
} spinlock(*(s->sl));
block(semaphore *s) { (s->val)++;
x = dequeue(s->sl) and enqueue(readyq, x);
listappend(s->l, current);
spinunlock(*(s->sl));
spinunlock(&(s->sl)); }
schedule(); Question: there is race between A and B. Can
we guarantee bounded wait ?
}
Semaphore Implementation

Must guarantee that no two processes can execute wait ()
and signal () on the same semaphore at the same time

Thus, implementation becomes the critical section
problem where the wait and signal code are placed in the
critical section

Could now have busy waiting in critical section implementation

But implementation code is short

Little busy waiting if critical section rarely occupied

Note that applications may spend lots of time in critical
sections and therefore this is not a good solution
Semaphore in Linux
struct semaphore { void down(struct semaphore *sem)

raw_spinlock_t lock; {
unsigned long flags;
unsigned int count;
struct list_head wait_list;
raw_spin_lock_irqsave(&sem->lock, flags);
};
if (likely(sem->count > 0))
static noinline void __sched
sem->count--;
__down(struct semaphore *sem)
else
{
__down(sem);
__down_common(sem,
raw_spin_unlock_irqrestore(&sem->lock,
TASK_UNINTERRUPTIBLE, flags);
MAX_SCHEDULE_TIMEOUT);
}
}
Semaphore in Linux
static inline int __sched for (;;) {
__down_common(struct semaphore if (signal_pending_state(state, task))
*sem, long state, long timeout)
goto interrupted;
{
if (unlikely(timeout <= 0))
struct task_struct *task = current; goto timed_out;
struct semaphore_waiter waiter; __set_task_state(task, state);
list_add_tail(&waiter.list, &sem- raw_spin_unlock_irq(&sem->lock);
>wait_list);
timeout = schedule_timeout(timeout);
waiter.task = task; raw_spin_lock_irq(&sem->lock);
waiter.up = false; if (waiter.up)
return 0;
}
....
}
Deadlocks
Deadlock

two or more processes are waiting indefinitely for an event that can
be caused by only one of the waiting processes

Let S and Q be two semaphores initialized to 1
P0 P1
wait (S); wait (Q);
wait (Q); wait (S);
. .
. .
. .
signal (S); signal (Q);
signal (Q); signal (S);
Example of deadlock

Let’s see the pthreads program : deadlock.c

Same programe as on earlier slide, but with
pthread_mutex_lock();
Non-deadlock, but similar
situations

Starvation – indefinite blocking

A process may never be removed from the semaphore
queue in which it is suspended

Priority Inversion

Scheduling problem when lower-priority process holds a
lock needed by higher-priority process (so it can not pre-
empt lower priority process), and a medium priority
process (that does not need the lock) pre-empts lower
priority task, denying turn to higher priority task

Solved via priority-inheritance protocol : temporarily
enhance priority of lower priority task to highest
Livelock

Similar to deadlock, but processes keep doing
‘useless work’

E.g. two people meet in a corridor opposite each
other

Both move to left at same time

Then both move to right at same time

Keep Repeating!

No process able to progress, but each doing ‘some
work’ (not sleeping/waiting), state keeps changing
Livelock example
/* thread one runs in this function */ /* thread two runs in this function */
void *do work one(void *param) void *do work two(void *param)
{ {
int done = 0; int done = 0;
while (!done) { while (!done) {
pthread mutex lock(&first mutex); pthread mutex lock(&second mutex);
if ( pthread mutex trylock (&second mutex)) { if ( pthread mutex trylock (&first mutex)) {
/** /**
* Do some work * Do some work
*/ */
pthread mutex unlock(&second mutex); pthread mutex unlock(&first mutex);

pthread mutex unlock(&first mutex); pthread mutex unlock(&second mutex);


done = 1;
done = 1;
}
}
else
else
pthread mutex unlock(&second mutex);
pthread mutex unlock(&first mutex);
}
}
}
}
More on deadlocks

Under which conditions they can occur?

How can deadlocks be avoided/prevented?

How can a system recover if there is a
deadlock ?
System model for understanding
deadlocks

System consists of resources

Resource types R1, R2, . . ., Rm

CPU cycles, memory space, I/O devices

Resource: Most typically a lock, synchronization primitive

Each resource type Ri has Wi instances.

Each process utilizes a resource as follows:

request

use

release
Deadlock characterisation

Deadlock is possible only if ALL of these conditions are
TRUE at the same time

Mutual exclusion: only one process at a time can use a
resource

Hold and wait: a process holding at least one resource is
waiting to acquire additional resources held by other
processes

No preemption: a resource can be released only voluntarily
by the process holding it, after that process has completed its
task

Circular wait: there exists a set {P0, P1, …, Pn} of waiting
processes such that P0 is waiting for a resource that is held
by P1, P1 is waiting for a resource that is held by P2, …, Pn–1
is waiting for a resource that is held by Pn, and Pn is waiting
for a resource that is held by P0.
Resource-Allocation Graph

A set of vertices V and a set of edges E

V is partitioned into two types:

P = {P1, P2, …, Pn}, the set consisting of all the
processes in the system

R = {R1, R2, …, Rm}, the set consisting of all
resource types in the system

request edge – directed edge Pi -> Rj

assignment edge – directed edge Rj -> Pi
Resource Allocation Graph
Example

One instance of R1

Two instances of R2

One instance of R3

Three instance of R4

T1 holds one instance of R2
and is waiting for an instance
of R1

T2 holds one instance of R1,
one instance of R2, and is
waiting for an instance of R3

T3 is holds one instance of R3
Resource Allocation Graph with a
Deadlock
Graph with a Cycle But no
Deadlock
Basic Facts

If graph contains no cycles -> no deadlock

If graph contains a cycle :

if only one instance per resource type, then
deadlock

if several instances per resource type,
possibility of deadlock
Methods for Handling Deadlocks

Ensure that the system will never enter a
deadlock state:
1) Deadlock prevention
2) Deadlock avoidance
3) Allow the system to enter a deadlock
state and then recover
4) Ignore the problem and pretend that
deadlocks never occur in the system.
(1) Deadlock Prevention

Invalidate one of the four necessary conditions for
deadlock:

Mutual Exclusion – not required for sharable resources
(e.g., read-only files); must hold for non-sharable
resources

Hold and Wait – must guarantee that whenever a process
requests a resource, it does not hold any other resources

Require process to request and be allocated all its resources
before it begins execution, or allow process to request
resources only when the process has none allocated to it.

Low resource utilization; starvation possible
(1) Deadlock Prevention (Cont.)

No Preemption:

If a process that is holding some resources requests another
resource that cannot be immediately allocated to it, then all
resources currently being held are released

Preempted resources are added to the list of resources for
which the process is waiting

Process will be restarted only when it can regain its old
resources, as well as the new ones that it is requesting

Circular Wait:

Impose a total ordering of all resource types, and require that
each process requests resources in an increasing order of
enumeration
(1) Deadlock prevention: Circular
Wait

Invalidating the circular wait
condition is most common.

Simply assign each resource
(i.e., mutex locks) a unique
number.

Resources must be acquired in
order.

If:
first_mutex = 1
second_mutex = 5
code for thread_two could not be
written as follows:
(1) Preventing deadlock: cyclic
wait

Locking hierarchy : Highly preferred technique in
kernels

Decide an ordering among all ‘locks’

Ensure that on ALL code paths in the kernel, the
locks are obtained in the decided order!

Poses coding challenges!

A key differentiating factor in kernels

Do not look at only the current lock being taken, look
at all the locks the code may be holding at any given
point in code!
(1) Prevention in Xv6:
Lock Ordering

lock on the directory, a lock on the new file’s
inode, a lock on a disk block buffer, idelock,
and ptable.lock.
(2) Deadlock avoidance

Requires that the system has some additional a
priori information available

Simplest and most useful model requires that each
process declare the maximum number of resources of
each type that it may need

The deadlock-avoidance algorithm dynamically
examines the resource-allocation state to ensure that
there can never be a circular-wait condition

Resource-allocation state is defined by the number of
available and allocated resources, and the maximum
demands of the processes
(2) Deadlock avoidance

Please see: concept of safe states, unsafe
states, Banker’s algorithm
(3) Deadlock detection and
recovery

How to detect a deadlock in the system?

The Resource-Allocation Graph is a graph. Need an algorithm
to detect cycle in a graph.

How to recover?

Abort all processes or abort one by one?

Which processes to abort?

Priority ?

Time spent since forked()?

Resources used?

Resources needed?

Interactive or not?

How many need to be terminated?
Different uses of semaphores
For mutual exclusion
/*During inialization*/
semaphore sem;
initsem (&sem, 1);

/* On each use*/
P (&sem);
Use resource;
V (&sem);
Event-wait
/* During initialization */
semaphore event;
initsem (&event, 0); /* probably at boot time */

/* Code executed by thread that must wait on event */


P (&event); /* Blocks if event has not occurred */
/* Event has occurred */
V (&event); /* So that another thread may wake up */
/* Continue processing */

/* Code executed by another thread when event occurs */


V (&event); /* Wake up one thread */
Control countable resources
/* During initialization */
semaphore counter;
initsem (&counter, resourceCount);
/* Code executed to use the resource */
P (&counter); /* Blocks until resource is available */
Use resource; /* Guaranteed to be available now */
V (&counter); /* Release the resource */
Drawbacks of semaphores

Need to be implemented using lower level
primitives like spinlocks

Context-switch is involved in blocking and
signaling – time consuming

Can not be used for a short critical section
“Condition”
Synchronization Tool
What is condition variable?

A variable with a sleep queue

Threads can sleep on it, and wake-up all remaining
Struct condition {
Proc *next
Proc *prev
Spinlock *lock
}
Different variables of this type can be used as different
‘conditions
Code for condition variables
//Spinlock s is held before calling wait void do_signal (condition *c)

/*Wakeup one thread waiting on thecondition*/
void wait (condition *c, spinlock_t *s)
{
(
spin_lock (&c->listLock);
spin_lock (&c->listLock); remove one thread from linked list, if it is nonempty;
add self to the linked list; spin_unlock (&c->listLock);
spin_unlock (&c->listLock); if a thread was removed from the list, make it
runnable;
spin_unlock (s); /* release
return;
spinlock before blocking */ }
swtch(); /* perform context switch */ void do broadcast (condition *c)
/* When we return from swtch, the /*Wakeup al lthreads waiting on the condition*/
event has occurred */ {
spin_lock (s); /* acquire the spin spin_lock (&c->listLock);
lock again */ while (linked list is nonempty) {
remove a thread from linked list;
return;
make it runnable;
)
}
spin_unlock (&c->listLock);
}
Semaphore implementation using
condition variables?

Is this possible?

Can we try it?
typedef struct semaphore {
//something
condition c;
}semaphore;

Now write code for semaphore P() and V()
Classical Synchronization Problems
Bounded-Buffer Problem

Producer and consumer processes

N buffers, each can hold one item

Producer produces ‘items’ to be consumed
by consumer , in the bounded buffer

Consumer should wait if there are no items

Producer should wait if the ‘bounded buffer’
is full
Bounded-Buffer Problem:
solution with semaphores

Semaphore mutex initialized to the value 1

Semaphore full initialized to the value 0

Semaphore empty initialized to the value N
Bounded-buffer problem
The structure of the producer The structure of the Consumer
process process
do { do {
// produce an item in nextp wait (full);
wait (empty); wait (mutex);
wait (mutex); // remove an item from
// add the item to the buffer // buffer to nextc
signal (mutex); signal (mutex);
signal (full); signal (empty);
} while (TRUE); // consume item in nextc
} while (TRUE);
Bounded buffer problem

Example : pipe()

Let’s see code of pipe in xv6 – a solution
using sleeplocks
Readers-Writers problem

A data set is shared among a number of concurrent processes

Readers – only read the data set; they do not perform any updates

Writers – can both read and write

Problem – allow multiple readers to read at the same time

Only one single writer can access the shared data at the same time

Several variations of how readers and writers are treated – all
involve priorities

Shared Data

Data set

Semaphore mutex initialized to 1

Semaphore wrt initialized to 1

Integer readcount initialized to 0
The structure of a reader
The structure of a writer process process
do {
do {
wait (wrt) ;
// writing is performed wait (mutex) ;

signal (wrt) ; readcount ++ ;


} while (TRUE); if (readcount == 1)
wait (wrt) ;
signal (mutex)
// reading is performed
wait (mutex) ;
readcount - - ;

Readers-Writers if (readcount == 0)
signal (wrt) ;
problem signal (mutex) ;

} while (TRUE);
Readers-Writers Problem
Variations

First variation – no reader kept waiting unless
writer has permission to use shared object

Second variation – once writer is ready, it
performs write asap

Both may have starvation leading to even
more variations

Problem is solved on some systems by kernel
providing reader-writer locks
Reader-write lock

A lock with following operations on it

Lockshared()

Unlockshared()

LockExcl()

UnlockExcl()

Possible additions

Downgrade() -> from excl to shared

Upgrade() -> from shared to excl
Code for reader-writer locks
struct rwlock { void lockShared {struct rwlock *r)
(
int nActive; /* num of active spin_lock {&r->sl);
readers, or-1 if a writer is r->nPendingReads++;
active */ if (r->nPendingWrites > O)

int nPendi ngReads; wait (&r->canRead, &r->sl ); /*don'tstarve


writers */
int nPendingWrites; while {r->nActive < 0) /* someone has
exclusive lock */
spinlock_t sl; wait (&r->canRead, &r->sl);
condition canRead; r->nActive++;
r->nPendingReads--;
condition canWrite;
spin_unlock (&r->sl);
); )
Code for reader-writer locks
void unlockShared (struct rwlock void lockExclusive (struct rwlock
*r) *r)
{ (
spin_lock (&r->sl); spin_lock (&r->sl);
r->nActive--; r->nPendingWrltes++;
if (r->nActive == O) { while (r->nActive)
spin_unlock (&r->sl); wait (&r->canWrite, &r->sl);
do signal (&r->canWrite); r->nPendingWrites--;
} else r->nActive = -1;
spin_unlock (&r->M); spin_unlock (&r->sl);
) }
Code for reader-writer locks
void unlockExclusive (struct rwlock *r){
boolean t wakeReaders;
Try writing code for
spin_lock (&r->sl); downgrade and
r->nActive = O; upgrade
wakeReaders = (r->nPendingReads != 0);
spin_unlock (&r->sl);
if (wakeReaders)
do broadcast (&r->canRead); /* wake Try writing a reader-
allreaders */
else
writer lock using
do_signal (&r->canWrite); semaphores!
/*wakeasinglewrir */
}
Dining-Philosophers Problem

Philosophers spend their lives
thinking and eating

Don’t interact with their
neighbors, occasionally try to
pick up 2 chopsticks (one at a
time) to eat from bowl

Need both to eat, then release
both when done

In the case of 5 philosophers

Shared data

Bowl of rice (data set)

Semaphore chopstick [5] initialized
to 1
Dining philosophers: One
solution
The structure of Philosopher i:
do {
wait ( chopstick[i] );
wait ( chopStick[ (i + 1) % 5] );
// eat
signal ( chopstick[i] );
signal (chopstick[ (i + 1) % 5] );
// think
} while (TRUE);
What is the problem with this algorithm?
Dining philosophers: Possible
approaches

Allow at most four philosophers to be sitting
simultaneously at the table.

Allow a philosopher to pick up her chopsticks only
if both chopsticks are available

to do this, she must pick them up in a critical section

Use an asymmetric solution

that is, an odd-numbered philosopher picks up first her
left chopstick and then her right chopstick

whereas an even-numbered philosopher picks up her
right chopstick and then her left chopstick.
Other solutions to dining
philosopher’s problem

Using higher level synchronization
primitives like ‘monitors’

Practical Problems
Lost Wakeup problem

The sleep/wakeup mechanism does not function correctly on a
multiprocessor.

Consider a potential race:

Thread T1 has locked a resource R1.

Thread T2, running on another processor, tries to acquire the resource, and
finds it locked.

T2 calls sleep() to wait for the resource.

Between the time T2 finds the resource locked and the time it calls s]eep (), T1
frees the resource and proceeds to wake up all threads blocked on it.

Since T2 has not yet been put on the sleep queue, it will miss the wakeup.

The end result is that the resource is not locked, but T2 is blocked waiting for it
to be unlocked.

If no one else tries to access the resource, T2 could block indefinitely.

This is known as the lost wakeup problem,

Requires some mechanism to combine the test for the resource and the
call to sleep () into a single atomic operation.
Lost Wakeup problem
Thundering herd problem

Thundering Herd problem

On a multiprocessor, if several threads were locked the resource

Waking them all may cause them to be simultaneously scheduled on
different processors

and they would all fight for the same resource again.

Starvation

Even if only one thread was blocked on the resource, there is still a time
delay between its waking up and actually running.

In this interval, an unrelated thread may grab the resource causing the
awakened thread to block again. If this happens frequently, it could lead
to starvation of this thread.

This problem is not as acute on a uniprocessor, since by the time a
thread runs, whoever had locked the resource is likely to have released it.
Case Studies
Linux Synchronization

Prior to kernel Version 2.6, disables interrupts to
implement short critical sections

Version 2.6 and later, fully preemptive

Linux provides:

semaphores

spinlocks

reader-writer versions of both

Atomic integers

On single-cpu system, spinlocks replaced by enabling
and disabling kernel preemption
Linux Synchronization

Atomic variables
atomic_t is the type for atomic integer

Consider the variables
atomic_t counter;
int value;
Pthreads synchronization

Pthreads API is OS-independent

It provides:

mutex locks

condition variables

Non-portable extensions include:

read-write locks

spinlocks
Synchronization issues in xv6 kernel
Difference approaches

Pros and Cons of locks

Locks ensure serialization

Locks consume time !

Solution – 1

One big kernel lock

Too enefficient

Solution – 2

One lock per variable

Often un-necessary, many data structures get manipulated in once place,
one lock for all of them may work

Problem: ptable.lock for the entire array and every element within

Alternatively: one lock for array, one lock per array entry
Three types of code

System calls code

Can it be interruptible?

If yes, when?

Interrupt handler code

Disable interrupts during interrupt handling or not?

Deadlock with iderw ! - already seen

Process’s user code

Ignore. Not concerned with it now.
Interrupts enabling/disablilng in
xv6

Holding every spinlock disables interrupts!

System call code or Interrupt handler code
won’t be interrupted if

The code path followed took at least once
spinlock !

Interrupts disabled only on that processor!

Acquire calls pushcli() before xchg()

Release calls popclu() after xchg()
Memory ordering
Compiler may generate machine

code for out-of-order execution !



Consider this

Processor pipelines can also do 1)l = malloc(sizeof *l);
the same!

This often improves performance
2)l->data = data;

Compiler m1ay reorder 4 after 6 3)acquire(&listlock);
--> Troble!
4)l->next = list;

Solution: Memory barrier

__sync_synchronize(), provided by 5)list = l;
GCC

Do not reorder across this line 6)release(&listlock);

Done only on acquire and release()
Lost Wakeup?

Do we have this problem in xv6?

Let’s analyze again!

The race in acquiresleep()’s call to sleep() and releasesleep()

T1 holding lock, T2 willing to acquire lock

Both running on different processor

Or both running on same processor

What happens in both scenarios?

Introduce a T3 and T4 on each of two different
processors. Now how does the scenario change?

See page 69 in xv6 book revision-11.
Code of sleep()
if(lk != &ptable.lock){
acquire(&ptable.lock);
release(lk);
}

Why this check?

Deadlock otherwise!

Check: wait() calls with ptable.lock held!
Exercise question : 1
Sleep has to check lk != &ptable.lock to avoid a deadlock
Suppose the special case were eliminated by replacing

if(lk != &ptable.lock){
acquire(&ptable.lock);
release(lk);
}
with
release(lk);
acquire(&ptable.lock);
Doing this would break sleep. How?
`
bget() problem

bget() panics if no free buffers!

Quite bad

Should sleep !

But that will introduce many deadlock
problems. Which ones ?
iget() and ilock()

iget() does no hold lock on inode

Ilock() does

Why this separation?

Performance? If you want only “read” the inode,
then why lock it?

What if iget() returned the inode locked?
Interesting cases in namex()
while((path = skipelem(path, name)) ! if((next = dirlookup(ip, name, 0)) == 0){
= 0){ iunlockput(ip);
ilock(ip); return 0;
if(ip->type != T_DIR){ }
iunlockput(ip); iunlockput(ip);
return 0; ip
} }
if(nameiparent && *path == '\0'){ --> only after obtaining next from
dirlookup() and iget() is the lock
// Stop one level early. released on ip;
iunlock(ip); -> lock on next obtained only after
return ip; releasing the lock on ip. Deadlock
possible if next was “.”
}
Xv6
Interesting case of holding and releasing
ptable.lock in scheduling

One process acquires, another releases!


Giving up CPU

A process that wants to give up the CPU

must acquire the process table lock ptable.lock

release any other locks it is holding

update its own state (proc->state),

and then call sched()

Yield follows this convention, as do sleep and exit

Lock held by one process P1, will be released another
process P2 that starts running after sched()

remember P2 returns either in yield() or sleep()

In both, the first thing done is releasing ptable.lock
Interesting race if ptable.lock is
not held

Suppose P1 calls yield()

Suppose yield() does not take ptable.lock

Remember yield() is for a process to give up CPU

Yield sets process state of P1 to RUNNABLE

Before yield’s sched() calls swtch()

Another processor runs scheduler() and runs P1 on
that processor

Now we have P1 running on both processors!

P1 in yield taking ptable.lock prevents this
Homework

Read the version-11 textbook of xv6

Solve the exercises!

You might also like