smp.c
上传用户:jlfgdled
上传日期:2013-04-10
资源大小:33168k
文件大小:13k
源码类别:

Linux/Unix编程

开发平台:

Unix_Linux

  1. /*
  2.  * BK Id: SCCS/s.smp.c 1.40 03/28/02 16:54:23 hozer
  3.  */
  4. /*
  5.  * Smp support for ppc.
  6.  *
  7.  * Written by Cort Dougan (cort@cs.nmt.edu) borrowing a great
  8.  * deal of code from the sparc and intel versions.
  9.  *
  10.  * Copyright (C) 1999 Cort Dougan <cort@cs.nmt.edu>
  11.  *
  12.  */
  13. #include <linux/config.h>
  14. #include <linux/kernel.h>
  15. #include <linux/sched.h>
  16. #include <linux/smp.h>
  17. #include <linux/smp_lock.h>
  18. #include <linux/interrupt.h>
  19. #include <linux/kernel_stat.h>
  20. #include <linux/delay.h>
  21. #define __KERNEL_SYSCALLS__
  22. #include <linux/unistd.h>
  23. #include <linux/init.h>
  24. #include <linux/spinlock.h>
  25. #include <linux/cache.h>
  26. #include <asm/ptrace.h>
  27. #include <asm/atomic.h>
  28. #include <asm/irq.h>
  29. #include <asm/page.h>
  30. #include <asm/pgtable.h>
  31. #include <asm/hardirq.h>
  32. #include <asm/softirq.h>
  33. #include <asm/io.h>
  34. #include <asm/prom.h>
  35. #include <asm/smp.h>
  36. #include <asm/residual.h>
  37. #include <asm/time.h>
  38. int smp_threads_ready;
  39. volatile int smp_commenced;
  40. int smp_num_cpus = 1;
  41. int smp_tb_synchronized;
  42. struct cpuinfo_PPC cpu_data[NR_CPUS];
  43. struct klock_info_struct klock_info = { KLOCK_CLEAR, 0 };
  44. atomic_t ipi_recv;
  45. atomic_t ipi_sent;
  46. spinlock_t kernel_flag __cacheline_aligned_in_smp = SPIN_LOCK_UNLOCKED;
  47. unsigned int prof_multiplier[NR_CPUS];
  48. unsigned int prof_counter[NR_CPUS];
  49. cycles_t cacheflush_time;
  50. static int max_cpus __initdata = NR_CPUS;
  51. unsigned long cpu_online_map;
  52. int smp_hw_index[NR_CPUS];
  53. static struct smp_ops_t *smp_ops;
  54. /* all cpu mappings are 1-1 -- Cort */
  55. volatile unsigned long cpu_callin_map[NR_CPUS];
  56. #define TB_SYNC_PASSES 4
  57. volatile unsigned long __initdata tb_sync_flag = 0;
  58. volatile unsigned long __initdata tb_offset = 0;
  59. int start_secondary(void *);
  60. extern int cpu_idle(void *unused);
  61. void smp_call_function_interrupt(void);
  62. /* Since OpenPIC has only 4 IPIs, we use slightly different message numbers.
  63.  * 
  64.  * Make sure this matches openpic_request_IPIs in open_pic.c, or what shows up
  65.  * in /proc/interrupts will be wrong!!! --Troy */
  66. #define PPC_MSG_CALL_FUNCTION 0
  67. #define PPC_MSG_RESCHEDULE 1
  68. #define PPC_MSG_INVALIDATE_TLB 2
  69. #define PPC_MSG_XMON_BREAK 3
  70. static inline void 
  71. smp_message_pass(int target, int msg, unsigned long data, int wait)
  72. {
  73. if (smp_ops){
  74. atomic_inc(&ipi_sent);
  75. smp_ops->message_pass(target,msg,data,wait);
  76. }
  77. }
  78. /* 
  79.  * Common functions
  80.  */
  81. void smp_local_timer_interrupt(struct pt_regs * regs)
  82. {
  83. int cpu = smp_processor_id();
  84. if (!--prof_counter[cpu]) {
  85. update_process_times(user_mode(regs));
  86. prof_counter[cpu]=prof_multiplier[cpu];
  87. }
  88. }
  89. void smp_message_recv(int msg, struct pt_regs *regs)
  90. {
  91. atomic_inc(&ipi_recv);
  92. switch( msg ) {
  93. case PPC_MSG_CALL_FUNCTION:
  94. smp_call_function_interrupt();
  95. break;
  96. case PPC_MSG_RESCHEDULE: 
  97. current->need_resched = 1;
  98. break;
  99. case PPC_MSG_INVALIDATE_TLB:
  100. _tlbia();
  101. break;
  102. #ifdef CONFIG_XMON
  103. case PPC_MSG_XMON_BREAK:
  104. xmon(regs);
  105. break;
  106. #endif /* CONFIG_XMON */
  107. default:
  108. printk("SMP %d: smp_message_recv(): unknown msg %dn",
  109.        smp_processor_id(), msg);
  110. break;
  111. }
  112. }
  113. #ifdef CONFIG_750_SMP
  114. /*
  115.  * 750's don't broadcast tlb invalidates so
  116.  * we have to emulate that behavior.
  117.  *   -- Cort
  118.  */
  119. void smp_ppc750_send_tlb_invalidate(int cpu)
  120. {
  121. if ( PVR_VER(mfspr(PVR)) == 8 )
  122. smp_message_pass(MSG_ALL_BUT_SELF, PPC_MSG_INVALIDATE_TLB, 0, 0);
  123. }
  124. #endif
  125. void smp_send_reschedule(int cpu)
  126. {
  127. /*
  128.  * This is only used if `cpu' is running an idle task,
  129.  * so it will reschedule itself anyway...
  130.  *
  131.  * This isn't the case anymore since the other CPU could be
  132.  * sleeping and won't reschedule until the next interrupt (such
  133.  * as the timer).
  134.  *  -- Cort
  135.  */
  136. /* This is only used if `cpu' is running an idle task,
  137.    so it will reschedule itself anyway... */
  138. smp_message_pass(cpu, PPC_MSG_RESCHEDULE, 0, 0);
  139. }
  140. #ifdef CONFIG_XMON
  141. void smp_send_xmon_break(int cpu)
  142. {
  143. smp_message_pass(cpu, PPC_MSG_XMON_BREAK, 0, 0);
  144. }
  145. #endif /* CONFIG_XMON */
  146. static void stop_this_cpu(void *dummy)
  147. {
  148. __cli();
  149. while (1)
  150. ;
  151. }
  152. void smp_send_stop(void)
  153. {
  154. smp_call_function(stop_this_cpu, NULL, 1, 0);
  155. smp_num_cpus = 1;
  156. }
  157. /*
  158.  * Structure and data for smp_call_function(). This is designed to minimise
  159.  * static memory requirements. It also looks cleaner.
  160.  * Stolen from the i386 version.
  161.  */
  162. static spinlock_t call_lock = SPIN_LOCK_UNLOCKED;
  163. static struct call_data_struct {
  164. void (*func) (void *info);
  165. void *info;
  166. atomic_t started;
  167. atomic_t finished;
  168. int wait;
  169. } *call_data;
  170. /*
  171.  * this function sends a 'generic call function' IPI to all other CPUs
  172.  * in the system.
  173.  */
  174. int smp_call_function (void (*func) (void *info), void *info, int nonatomic,
  175. int wait)
  176. /*
  177.  * [SUMMARY] Run a function on all other CPUs.
  178.  * <func> The function to run. This must be fast and non-blocking.
  179.  * <info> An arbitrary pointer to pass to the function.
  180.  * <nonatomic> currently unused.
  181.  * <wait> If true, wait (atomically) until function has completed on other CPUs.
  182.  * [RETURNS] 0 on success, else a negative status code. Does not return until
  183.  * remote CPUs are nearly ready to execute <<func>> or are or have executed.
  184.  *
  185.  * You must not call this function with disabled interrupts or from a
  186.  * hardware interrupt handler, you may call it from a bottom half handler.
  187.  */
  188. {
  189. struct call_data_struct data;
  190. int ret = -1, cpus = smp_num_cpus-1;
  191. int timeout;
  192. if (!cpus)
  193. return 0;
  194. data.func = func;
  195. data.info = info;
  196. atomic_set(&data.started, 0);
  197. data.wait = wait;
  198. if (wait)
  199. atomic_set(&data.finished, 0);
  200. spin_lock_bh(&call_lock);
  201. call_data = &data;
  202. /* Send a message to all other CPUs and wait for them to respond */
  203. smp_message_pass(MSG_ALL_BUT_SELF, PPC_MSG_CALL_FUNCTION, 0, 0);
  204. /* Wait for response */
  205. timeout = 1000000;
  206. while (atomic_read(&data.started) != cpus) {
  207. if (--timeout == 0) {
  208. printk("smp_call_function on cpu %d: other cpus not responding (%d)n",
  209.        smp_processor_id(), atomic_read(&data.started));
  210. goto out;
  211. }
  212. barrier();
  213. udelay(1);
  214. }
  215. if (wait) {
  216. timeout = 1000000;
  217. while (atomic_read(&data.finished) != cpus) {
  218. if (--timeout == 0) {
  219. printk("smp_call_function on cpu %d: other cpus not finishing (%d/%d)n",
  220.        smp_processor_id(), atomic_read(&data.finished), atomic_read(&data.started));
  221. goto out;
  222. }
  223. barrier();
  224. udelay(1);
  225. }
  226. }
  227. ret = 0;
  228.  out:
  229. spin_unlock_bh(&call_lock);
  230. return ret;
  231. }
  232. void smp_call_function_interrupt(void)
  233. {
  234. void (*func) (void *info) = call_data->func;
  235. void *info = call_data->info;
  236. int wait = call_data->wait;
  237. /*
  238.  * Notify initiating CPU that I've grabbed the data and am
  239.  * about to execute the function
  240.  */
  241. atomic_inc(&call_data->started);
  242. /*
  243.  * At this point the info structure may be out of scope unless wait==1
  244.  */
  245. (*func)(info);
  246. if (wait)
  247. atomic_inc(&call_data->finished);
  248. }
  249. void __init smp_boot_cpus(void)
  250. {
  251. extern struct task_struct *current_set[NR_CPUS];
  252. int i, cpu_nr;
  253. struct task_struct *p;
  254. printk("Entering SMP Mode...n");
  255. smp_num_cpus = 1;
  256.         smp_store_cpu_info(0);
  257. cpu_online_map = 1UL;
  258. /*
  259.  * assume for now that the first cpu booted is
  260.  * cpu 0, the master -- Cort
  261.  */
  262. cpu_callin_map[0] = 1;
  263. current->processor = 0;
  264. init_idle();
  265. for (i = 0; i < NR_CPUS; i++) {
  266. prof_counter[i] = 1;
  267. prof_multiplier[i] = 1;
  268. }
  269. /*
  270.  * XXX very rough, assumes 20 bus cycles to read a cache line,
  271.  * timebase increments every 4 bus cycles, 32kB L1 data cache.
  272.  */
  273. cacheflush_time = 5 * 1024;
  274. smp_ops = ppc_md.smp_ops;
  275. if (smp_ops == NULL) {
  276. printk("SMP not supported on this machine.n");
  277. return;
  278. }
  279. #ifndef CONFIG_750_SMP
  280. /* check for 750's, they just don't work with linux SMP.
  281.  * If you actually have 750 SMP hardware and want to try to get
  282.  * it to work, send me a patch to make it work and
  283.  * I'll make CONFIG_750_SMP a config option.  -- Troy (hozer@drgw.net)
  284.  */
  285. if ( PVR_VER(mfspr(PVR)) == 8 ){
  286. printk("SMP not supported on 750 cpus. %s line %dn",
  287. __FILE__, __LINE__);
  288. return;
  289. }
  290. #endif
  291. /* Probe arch for CPUs */
  292. cpu_nr = smp_ops->probe();
  293. /*
  294.  * only check for cpus we know exist.  We keep the callin map
  295.  * with cpus at the bottom -- Cort
  296.  */
  297. if (cpu_nr > max_cpus)
  298. cpu_nr = max_cpus;
  299. for (i = 1; i < cpu_nr; i++) {
  300. int c;
  301. struct pt_regs regs;
  302. /* create a process for the processor */
  303. /* only regs.msr is actually used, and 0 is OK for it */
  304. memset(&regs, 0, sizeof(struct pt_regs));
  305. if (do_fork(CLONE_VM|CLONE_PID, 0, &regs, 0) < 0)
  306. panic("failed fork for CPU %d", i);
  307. p = init_task.prev_task;
  308. if (!p)
  309. panic("No idle task for CPU %d", i);
  310. del_from_runqueue(p);
  311. unhash_process(p);
  312. init_tasks[i] = p;
  313. p->processor = i;
  314. p->cpus_runnable = 1 << i; /* we schedule the first task manually */
  315. current_set[i] = p;
  316. /*
  317.  * There was a cache flush loop here to flush the cache
  318.  * to memory for the first 8MB of RAM.  The cache flush
  319.  * has been pushed into the kick_cpu function for those
  320.  * platforms that need it.
  321.  */
  322. /* wake up cpus */
  323. smp_ops->kick_cpu(i);
  324. /*
  325.  * wait to see if the cpu made a callin (is actually up).
  326.  * use this value that I found through experimentation.
  327.  * -- Cort
  328.  */
  329. for ( c = 1000; c && !cpu_callin_map[i] ; c-- )
  330. udelay(100);
  331. if ( cpu_callin_map[i] )
  332. {
  333. char buf[32];
  334. sprintf(buf, "found cpu %d", i);
  335. if (ppc_md.progress) ppc_md.progress(buf, 0x350+i);
  336. printk("Processor %d found.n", i);
  337. smp_num_cpus++;
  338. } else {
  339. char buf[32];
  340. sprintf(buf, "didn't find cpu %d", i);
  341. if (ppc_md.progress) ppc_md.progress(buf, 0x360+i);
  342. printk("Processor %d is stuck.n", i);
  343. }
  344. }
  345. /* Setup CPU 0 last (important) */
  346. smp_ops->setup_cpu(0);
  347. if (smp_num_cpus < 2)
  348. smp_tb_synchronized = 1;
  349. }
  350. void __init smp_software_tb_sync(int cpu)
  351. {
  352. #define PASSES 4 /* 4 passes.. */
  353. int pass;
  354. int i, j;
  355. /* stop - start will be the number of timebase ticks it takes for cpu0
  356.  * to send a message to all others and the first reponse to show up.
  357.  *
  358.  * ASSUMPTION: this time is similiar for all cpus
  359.  * ASSUMPTION: the time to send a one-way message is ping/2
  360.  */
  361. register unsigned long start = 0;
  362. register unsigned long stop = 0;
  363. register unsigned long temp = 0;
  364. set_tb(0, 0);
  365. /* multiple passes to get in l1 cache.. */
  366. for (pass = 2; pass < 2+PASSES; pass++){
  367. if (cpu == 0){
  368. mb();
  369. for (i = j = 1; i < smp_num_cpus; i++, j++){
  370. /* skip stuck cpus */
  371. while (!cpu_callin_map[j])
  372. ++j;
  373. while (cpu_callin_map[j] != pass)
  374. barrier();
  375. }
  376. mb();
  377. tb_sync_flag = pass;
  378. start = get_tbl(); /* start timing */
  379. while (tb_sync_flag)
  380. mb();
  381. stop = get_tbl(); /* end timing */
  382. /* theoretically, the divisor should be 2, but
  383.  * I get better results on my dual mtx. someone
  384.  * please report results on other smp machines..
  385.  */
  386. tb_offset = (stop-start)/4;
  387. mb();
  388. tb_sync_flag = pass;
  389. udelay(10);
  390. mb();
  391. tb_sync_flag = 0;
  392. mb();
  393. set_tb(0,0);
  394. mb();
  395. } else {
  396. cpu_callin_map[cpu] = pass;
  397. mb();
  398. while (!tb_sync_flag)
  399. mb(); /* wait for cpu0 */
  400. mb();
  401. tb_sync_flag = 0; /* send response for timing */
  402. mb();
  403. while (!tb_sync_flag)
  404. mb();
  405. temp = tb_offset; /* make sure offset is loaded */
  406. while (tb_sync_flag)
  407. mb();
  408. set_tb(0,temp); /* now, set the timebase */
  409. mb();
  410. }
  411. }
  412. if (cpu == 0) {
  413. smp_tb_synchronized = 1;
  414. printk("smp_software_tb_sync: %d passes, final offset: %ldn",
  415. PASSES, tb_offset);
  416. }
  417. /* so time.c doesn't get confused */
  418. set_dec(tb_ticks_per_jiffy);
  419. last_jiffy_stamp(cpu) = 0;
  420. }
  421. void __init smp_commence(void)
  422. {
  423. /*
  424.  * Lets the callin's below out of their loop.
  425.  */
  426. if (ppc_md.progress) ppc_md.progress("smp_commence", 0x370);
  427. wmb();
  428. smp_commenced = 1;
  429. /* if the smp_ops->setup_cpu function has not already synched the
  430.  * timebases with a nicer hardware-based method, do so now
  431.  *
  432.  * I am open to suggestions for improvements to this method
  433.  * -- Troy <hozer@drgw.net>
  434.  *
  435.  * NOTE: if you are debugging, set smp_tb_synchronized for now
  436.  * since if this code runs pretty early and needs all cpus that
  437.  * reported in in smp_callin_map to be working
  438.  *
  439.  * NOTE2: this code doesn't seem to work on > 2 cpus. -- paulus/BenH
  440.  */
  441. if (!smp_tb_synchronized && smp_num_cpus == 2) {
  442. unsigned long flags;
  443. __save_and_cli(flags);
  444. smp_software_tb_sync(0);
  445. __restore_flags(flags);
  446. }
  447. }
  448. void __init smp_callin(void)
  449. {
  450. int cpu = current->processor;
  451.         smp_store_cpu_info(cpu);
  452. set_dec(tb_ticks_per_jiffy);
  453. cpu_callin_map[cpu] = 1;
  454. smp_ops->setup_cpu(cpu);
  455. /*
  456.  * This cpu is now "online".  Only set them online
  457.  * before they enter the loop below since write access
  458.  * to the below variable is _not_ guaranteed to be
  459.  * atomic.
  460.  *   -- Cort <cort@fsmlabs.com>
  461.  */
  462. cpu_online_map |= 1UL << smp_processor_id();
  463. while(!smp_commenced)
  464. barrier();
  465. /* see smp_commence for more info */
  466. if (!smp_tb_synchronized && smp_num_cpus == 2) {
  467. smp_software_tb_sync(cpu);
  468. }
  469. __sti();
  470. }
  471. /* intel needs this */
  472. void __init initialize_secondary(void)
  473. {
  474. }
  475. /* Activate a secondary processor. */
  476. int __init start_secondary(void *unused)
  477. {
  478. atomic_inc(&init_mm.mm_count);
  479. current->active_mm = &init_mm;
  480. smp_callin();
  481. return cpu_idle(NULL);
  482. }
  483. void __init smp_setup(char *str, int *ints)
  484. {
  485. }
  486. int __init setup_profiling_timer(unsigned int multiplier)
  487. {
  488. return 0;
  489. }
  490. void __init smp_store_cpu_info(int id)
  491. {
  492.         struct cpuinfo_PPC *c = &cpu_data[id];
  493. /* assume bogomips are same for everything */
  494.         c->loops_per_jiffy = loops_per_jiffy;
  495.         c->pvr = mfspr(PVR);
  496. }
  497. static int __init maxcpus(char *str)
  498. {
  499. get_option(&str, &max_cpus);
  500. return 1;
  501. }
  502. __setup("maxcpus=", maxcpus);