Searched refs:scheduler (Results 1 - 200 of 310) sorted by relevance

12

/linux-4.4.14/net/netfilter/ipvs/
H A Dip_vs_sched.c34 * IPVS scheduler list
43 * Bind a service with a scheduler
46 struct ip_vs_scheduler *scheduler) ip_vs_bind_scheduler()
50 if (scheduler->init_service) { ip_vs_bind_scheduler()
51 ret = scheduler->init_service(svc); ip_vs_bind_scheduler()
57 rcu_assign_pointer(svc->scheduler, scheduler); ip_vs_bind_scheduler()
63 * Unbind a service with its scheduler
70 cur_sched = rcu_dereference_protected(svc->scheduler, 1); ip_vs_unbind_scheduler()
77 /* svc->scheduler can be set to NULL only by caller */ ip_vs_unbind_scheduler()
82 * Get scheduler in the scheduler list by name
98 * This scheduler is just deleted ip_vs_sched_getbyname()
116 * Lookup scheduler and try to load it if it doesn't exist
123 * Search for the scheduler by sched_name ip_vs_scheduler_get()
128 * If scheduler not found, load the module and search again ip_vs_scheduler_get()
138 void ip_vs_scheduler_put(struct ip_vs_scheduler *scheduler) ip_vs_scheduler_put() argument
140 if (scheduler) ip_vs_scheduler_put()
141 module_put(scheduler->module); ip_vs_scheduler_put()
150 struct ip_vs_scheduler *sched = rcu_dereference(svc->scheduler); ip_vs_scheduler_err()
170 * Register a scheduler in the scheduler list
172 int register_ip_vs_scheduler(struct ip_vs_scheduler *scheduler) register_ip_vs_scheduler() argument
176 if (!scheduler) { register_ip_vs_scheduler()
181 if (!scheduler->name) { register_ip_vs_scheduler()
191 if (!list_empty(&scheduler->n_list)) { register_ip_vs_scheduler()
194 pr_err("%s(): [%s] scheduler already linked\n", register_ip_vs_scheduler()
195 __func__, scheduler->name); register_ip_vs_scheduler()
200 * Make sure that the scheduler with this name doesn't exist register_ip_vs_scheduler()
201 * in the scheduler list. register_ip_vs_scheduler()
204 if (strcmp(scheduler->name, sched->name) == 0) { register_ip_vs_scheduler()
207 pr_err("%s(): [%s] scheduler already existed " register_ip_vs_scheduler()
208 "in the system\n", __func__, scheduler->name); register_ip_vs_scheduler()
213 * Add it into the d-linked scheduler list register_ip_vs_scheduler()
215 list_add(&scheduler->n_list, &ip_vs_schedulers); register_ip_vs_scheduler()
218 pr_info("[%s] scheduler registered.\n", scheduler->name); register_ip_vs_scheduler()
225 * Unregister a scheduler from the scheduler list
227 int unregister_ip_vs_scheduler(struct ip_vs_scheduler *scheduler) unregister_ip_vs_scheduler() argument
229 if (!scheduler) { unregister_ip_vs_scheduler()
235 if (list_empty(&scheduler->n_list)) { unregister_ip_vs_scheduler()
237 pr_err("%s(): [%s] scheduler is not in the list. failed\n", unregister_ip_vs_scheduler()
238 __func__, scheduler->name); unregister_ip_vs_scheduler()
243 * Remove it from the d-linked scheduler list unregister_ip_vs_scheduler()
245 list_del(&scheduler->n_list); unregister_ip_vs_scheduler()
251 pr_info("[%s] scheduler unregistered.\n", scheduler->name); unregister_ip_vs_scheduler()
45 ip_vs_bind_scheduler(struct ip_vs_service *svc, struct ip_vs_scheduler *scheduler) ip_vs_bind_scheduler() argument
H A Dip_vs_ovf.c15 * Note that this scheduler might not be suitable for UDP because it only uses
H A Dip_vs_dh.c6 * Inspired by the consistent hashing scheduler patch from
31 * array. If the dh scheduler is used in cache cluster, it is good to
H A Dip_vs_ctl.c846 sched = rcu_dereference_protected(svc->scheduler, 1); __ip_vs_update_dest()
850 sched = rcu_dereference_protected(svc->scheduler, 1); __ip_vs_update_dest()
1082 sched = rcu_dereference_protected(svc->scheduler, 1); __ip_vs_unlink_dest()
1171 /* Lookup the scheduler by 'u->sched_name' */ ip_vs_add_service()
1239 /* Bind the scheduler */
1288 * Edit a service and bind it with a new scheduler
1298 * Lookup the scheduler, by 'u->sched_name' ip_vs_edit_service()
1332 old_sched = rcu_dereference_protected(svc->scheduler, 1); ip_vs_edit_service()
1336 RCU_INIT_POINTER(svc->scheduler, NULL); ip_vs_edit_service()
1340 /* Bind the new scheduler */ ip_vs_edit_service()
1387 /* Unbind scheduler */ __ip_vs_del_service()
1388 old_sched = rcu_dereference_protected(svc->scheduler, 1); __ip_vs_del_service()
2005 struct ip_vs_scheduler *sched = rcu_dereference(svc->scheduler); ip_vs_info_seq_show()
2464 sched = rcu_dereference_protected(src->scheduler, 1); ip_vs_copy_service()
2952 sched = rcu_dereference_protected(svc->scheduler, 1); ip_vs_genl_fill_service()
H A Dip_vs_core.c331 sched = rcu_dereference(svc->scheduler); ip_vs_sched_persist()
333 /* read svc->sched_data after svc->scheduler */ ip_vs_sched_persist()
410 * svc/scheduler decides that this packet should be accepted with
413 * 0 : scheduler can not find destination, so try bypass or
416 * -1 : scheduler tried to schedule but fatal error occurred, eg.
504 sched = rcu_dereference(svc->scheduler); ip_vs_schedule()
506 /* read svc->sched_data after svc->scheduler */ ip_vs_schedule()
H A Dip_vs_sh.c28 * array. If the sh scheduler is used in cache cluster, it is good to
H A Dip_vs_lblcr.c2 * IPVS: Locality-Based Least-Connection with Replication scheduler
/linux-4.4.14/drivers/gpu/drm/amd/amdgpu/
H A DMakefile8 -Idrivers/gpu/drm/amd/scheduler
87 # GPU scheduler
89 ../scheduler/gpu_scheduler.o \
90 ../scheduler/sched_fence.o \
H A Damdgpu_ring.c444 * Extract the ring a fence belongs to. Handles both scheduler as
H A Damdgpu_fence.c495 * so the scheduler will not use delayed workqueue if amdgpu_fence_driver_init_ring()
505 DRM_ERROR("Failed to create scheduler on ring %s.\n", amdgpu_fence_driver_init_ring()
H A Damdgpu_drv.c155 MODULE_PARM_DESC(enable_scheduler, "enable SW GPU scheduler (1 = enable (default), 0 = disable)");
/linux-4.4.14/drivers/gpu/drm/amd/scheduler/
H A Dgpu_scheduler.c108 * Init a context entity used by scheduler when submit to HW ring.
110 * @sched The pointer to the scheduler
150 * @sched Pointer to scheduler instance
151 * @entity The pointer to a valid scheduler entity
165 * @entity The pointer to a valid scheduler entity
181 * @entity The pointer to a valid scheduler entity
199 * @sched Pointer to scheduler instance
200 * @entity The pointer to a valid scheduler entity
245 /* Fence is from the same scheduler */ amd_sched_entity_add_dependency_cb()
304 /* first job wakes up scheduler */ amd_sched_entity_in()
337 * Wake up the scheduler when it is ready
392 DRM_ERROR("[%s] scheduler is timeout!\n", sched->name); amd_sched_fence_work_func()
468 * Init a gpu scheduler instance
470 * @sched The pointer to the scheduler
471 * @ops The backend operations for this scheduler.
499 /* Each scheduler will run on a seperate kernel thread */ amd_sched_init()
502 DRM_ERROR("Failed to create scheduler for %s.\n", name); amd_sched_init()
510 * Destroy a gpu scheduler
512 * @sched The pointer to the scheduler
H A Dgpu_scheduler.h39 * A scheduler entity is a wrapper around a job queue or a group
99 * Define the backend operations called by the scheduler,
108 * One scheduler is implemented for each hardware ring
/linux-4.4.14/arch/arm/mach-gemini/
H A Didle.c14 * interrupts first since scheduler can miss a tick, but there is gemini_idle()
/linux-4.4.14/arch/c6x/kernel/
H A Dtime.c43 * scheduler clock - returns current time in nanoseconds.
/linux-4.4.14/include/uapi/linux/
H A Derrqueue.h42 SCM_TSTAMP_SCHED, /* data entered the packet scheduler */
H A Dip_vs.h23 #define IP_VS_SVC_F_SCHED1 0x0008 /* scheduler flag 1 */
24 #define IP_VS_SVC_F_SCHED2 0x0010 /* scheduler flag 2 */
25 #define IP_VS_SVC_F_SCHED3 0x0020 /* scheduler flag 3 */
352 IPVS_SVC_ATTR_SCHED_NAME, /* name of scheduler */
H A Dpkt_sched.h6 /* Logical priority bands not depending on specific packet scheduler.
7 Every scheduler will map them to real traffic classes, if it has
/linux-4.4.14/sound/pci/mixart/
H A Dmixart_core.h230 u64 scheduler; member in struct:mixart_stream_state_req
243 u64 scheduler; member in struct:mixart_group_state_req
252 u64 scheduler; member in struct:mixart_group_state_resp
393 u64 scheduler; member in struct:mixart_stream_param_desc
444 u64 scheduler; member in struct:mixart_set_out_audio_level
504 u64 scheduler; member in struct:mixart_set_in_audio_level_req
549 u64 scheduler; member in struct:mixart_set_out_stream_level_req
/linux-4.4.14/tools/power/cpupower/bench/
H A Dsystem.c118 dprintf("set scheduler priority to %i\n", priority); set_process_priority()
124 fprintf(stderr, "warning: unable to set scheduler priority\n"); set_process_priority()
158 * sets up the cpu affinity and scheduler priority
H A Dparse.h33 enum sched_prio /* possible scheduler priorities */
H A Dparse.c37 * @param str string that represents a scheduler priority
/linux-4.4.14/drivers/staging/lustre/lnet/selftest/
H A Dmodule.c102 CERROR("Failed to create serial WI scheduler for LST\n"); lnet_selftest_init()
121 CERROR("Failed to create CPT affinity WI scheduler %d for LST\n", lnet_selftest_init()
H A Drpc.c526 /* it's called by workitem scheduler threads, these threads srpc_add_buffer()
609 * allow to sleep inside thread context of WI scheduler srpc_service_add_buffers()
610 * because it will block current scheduler thread from doing srpc_service_add_buffers()
612 * waiting on result from another WI of the same scheduler. srpc_service_add_buffers()
614 * by thread in a different WI scheduler (lst_sched_test), srpc_service_add_buffers()
/linux-4.4.14/block/
H A Dblk-exec.c45 * Insert a fully prepared request at the back of the I/O scheduler queue
96 * Insert a fully prepared request at the back of the I/O scheduler queue
H A Dnoop-iosched.c124 MODULE_DESCRIPTION("No-op IO scheduler");
H A Delevator.c2 * Block device elevator/IO-scheduler.
53 * Query io scheduler to see if the current process issuing bio may be
213 printk(KERN_ERR "I/O scheduler %s not found\n", elevator_init()
221 "Default I/O scheduler not found. " \ elevator_init()
863 printk(KERN_INFO "io scheduler %s registered%s\n", e->elevator_name, elv_register()
889 * switch to new_e io scheduler. be careful not to introduce deadlocks -
890 * we don't free the old io scheduler, before we have allocated what we
948 * Switch this queue to the given IO scheduler.
H A Ddeadline-iosched.c2 * Deadline i/o scheduler.
46 * settings that change how the i/o scheduler behaves
476 MODULE_DESCRIPTION("deadline IO scheduler");
H A Dblk-sysfs.c390 .attr = {.name = "scheduler", .mode = S_IRUGO | S_IWUSR },
H A Dcfq-iosched.c2 * CFQ, or complete fairness queueing, disk scheduler.
5 * scheduler (round robin per-process disk scheduling) and Andrea Arcangeli.
86 * to find it. Idea borrowed from Ingo Molnars CFS scheduler. We should
184 /* total time spent waiting in scheduler queue in ns */
905 * scheduler run of queue, if there are requests pending and no one in the
4809 MODULE_DESCRIPTION("Completely Fair Queueing IO scheduler");
/linux-4.4.14/include/xen/interface/
H A Dsched.h17 * @cmd == SCHEDOP_??? (scheduler operation).
24 * @cmd == SCHEDOP_??? (scheduler operation).
/linux-4.4.14/arch/mn10300/kernel/
H A Dtime.c35 * scheduler clock - returns current time in nanosec units.
75 * initialise the scheduler clock
H A Dmn10300-serial-low.S62 # - induces a scheduler tick timer interrupt when done, which we then subvert
109 # - induces a scheduler tick timer interrupt when done, which we then subvert
H A Dprocess.c158 /* set up things up so the scheduler can start the new task */ copy_thread()
/linux-4.4.14/include/linux/sched/
H A Dprio.h37 * can work with better when scaling various scheduler parameters,
/linux-4.4.14/arch/sparc/include/asm/
H A Dswitch_to_64.h16 * past the invocation of switch_to in the scheduler, so we need
/linux-4.4.14/include/linux/
H A Dioprio.h51 * the cpu scheduler nice value to an io priority
H A Delevator.h145 * io scheduler registration
152 * io scheduler sysfs switching
H A Dworkqueue.h288 * workqueues exclude the scheduler from choosing the CPU to
292 * The scheduler considers a CPU idle if it doesn't have any task
295 * interrupt handler on an idle CPU will force the scheduler to
H A Dblk_types.h189 __REQ_HASHED, /* on IO scheduler merge hash */
H A Dpreempt.h122 * (used by the scheduler)
H A Dblkdev.h112 * The hash is used inside the scheduler, and killed once the
124 * The rb_node is only used inside the io scheduler, requests
136 * never put on the IO scheduler. So let the flush fields share
H A Dprintk.h145 * Special printk facility for scheduler/timekeeping use only, _DO_NOT_USE_ ! early_printk()
H A Dsched.h96 * @sched_flags for customizing the scheduler behaviour
608 * Disable preemption until the scheduler is running -- use an unconditional
1314 unsigned int flags; /* specifying the scheduler behaviour */
1460 /* scheduler bits, serialized by scheduler locks */
/linux-4.4.14/tools/testing/selftests/powerpc/pmu/ebb/
H A Dpmae_handling_test.c20 * encourage the scheduler to switch us.
/linux-4.4.14/drivers/net/wireless/iwlwifi/
H A Diwl-prph.h185 * 1) Scheduler-Ack, in which the scheduler automatically supports a
191 * In scheduler-ack mode, the scheduler keeps track of the Tx status of
210 * Driver controls scheduler operation via 3 means:
212 * 2) Shared scheduler data base in internal SRAM
223 * the scheduler (especially for queue #4/#9, the command queue, otherwise
229 * Max Tx window size is the max number of contiguous TFDs that the scheduler
H A Diwl-fh.h407 * command was received from the scheduler while the TRB was already full
526 * struct iwlagn_schedq_bc_tbl scheduler byte count table
/linux-4.4.14/drivers/staging/lustre/lustre/libcfs/
H A Dworkitem.c62 /** CPT-table for this scheduler */
68 /** started scheduler thread, protected by cfs_wi_data::wi_glock */
74 /** scheduler name */
226 /* CPT affinity scheduler? */ cfs_wi_scheduler()
405 CERROR("Failed to create thread for WI scheduler %s: %d\n", cfs_wi_sched_create()
H A Dmodule.c714 CERROR("Startup workitem scheduler: error: %d\n", rc); init_libcfs_module()
/linux-4.4.14/drivers/net/wireless/iwlegacy/
H A Dprph.h236 /* 3945 Tx scheduler registers */
275 * 1) Scheduler-Ack, in which the scheduler automatically supports a
281 * In scheduler-ack mode, the scheduler keeps track of the Tx status of
300 * Driver controls scheduler operation via 3 means:
302 * 2) Shared scheduler data base in internal 4956 SRAM
313 * the scheduler (especially for queue #4/#9, the command queue, otherwise
318 * Max Tx win size is the max number of contiguous TFDs that the scheduler
331 * 4965 tells driver SRAM address for internal scheduler structs via this reg.
339 * scheduler is not tracking what's happening).
380 * Initialized by driver, updated by scheduler.
396 * Select which queues interrupt driver when scheduler increments
415 * 5: Window Size Left; indicates whether scheduler can request
439 * 4965 internal SRAM structures for scheduler, shared with driver ...
450 * Driver reads base address of this scheduler area from SCD_SRAM_BASE_ADDR.
/linux-4.4.14/drivers/staging/lustre/include/linux/libcfs/
H A Dlibcfs_workitem.h61 * freed or reused and workitem scheduler won't touch it any more.
107 /** # workitem scheduler loops before reschedule */
/linux-4.4.14/drivers/staging/rtl8712/
H A Drtl8712_cmdctrl_bitdef.h33 #define _SCHEDULE_EN BIT(10) /*Enable MAC scheduler*/
/linux-4.4.14/drivers/block/paride/
H A Dpseudo.h21 the scheduler runs (by adding it to a task queue). If
/linux-4.4.14/arch/c6x/include/asm/
H A Dthread_info.h52 * preempt_count needs to be 1 initially, until the scheduler is functional.
/linux-4.4.14/arch/score/include/asm/
H A Dthread_info.h50 * preempt_count needs to be 1 initially, until the scheduler is functional.
/linux-4.4.14/include/net/
H A Dip_vs.h638 struct ip_vs_scheduler __rcu *scheduler; /* bound scheduler object */ member in struct:ip_vs_service
640 void *sched_data; /* scheduler application data */
696 /* The scheduler object */
699 char *name; /* scheduler name */
703 /* scheduler initializing service */
723 char *name; /* scheduler name */
1350 /* Registering/unregistering scheduler functions
1353 int register_ip_vs_scheduler(struct ip_vs_scheduler *scheduler);
1354 int unregister_ip_vs_scheduler(struct ip_vs_scheduler *scheduler);
1356 struct ip_vs_scheduler *scheduler);
1360 void ip_vs_scheduler_put(struct ip_vs_scheduler *scheduler);
/linux-4.4.14/drivers/isdn/hardware/eicon/
H A Dsdp_hdr.h82 This function is called from system scheduler or from timer
/linux-4.4.14/drivers/net/wireless/rt2x00/
H A Drt2800usb.h51 * QSEL: Select on-chip FIFO ID for 2nd-stage output scheduler.
H A Drt2800mmio.h74 * QSEL: Select on-chip FIFO ID for 2nd-stage output scheduler.
/linux-4.4.14/arch/unicore32/include/asm/
H A Dmmu_context.h43 * This is the actual mm switch as far as the scheduler
/linux-4.4.14/arch/x86/crypto/sha-mb/
H A Dsha_mb_mgr.h77 /* SHA1 out-of-order scheduler */
/linux-4.4.14/arch/x86/crypto/
H A Dsha512-ssse3-asm.S129 add WK_2(idx), T1 # W[t] + K[t] from message scheduler
160 # scheduler.
170 # by one tab. Vectored instructions (for the message scheduler) are indented
311 # +1 iteration because the scheduler leads hashing by 1 iteration
H A Dsha512-avx-asm.S136 add WK_2(idx), T1 # W[t] + K[t] from message scheduler
166 # scheduler.
312 # +1 iteration because the scheduler leads hashing by 1 iteration
/linux-4.4.14/arch/arc/include/asm/
H A Dthread_info.h54 * preempt_count needs to be 1 initially, until the scheduler is functional.
/linux-4.4.14/net/sched/
H A Dsch_fifo.c20 /* 1 band FIFO pseudo-"scheduler" */
H A Dsch_generic.c2 * net/sched/sch_generic.c Generic packet scheduler routines.
380 /* "NOOP" scheduler: the best scheduler, recommended for all interfaces
452 * Private data for a pfifo_fast scheduler containing:
713 /* Prune old scheduler */ dev_graft_qdisc()
H A Dsch_mq.c2 * net/sched/sch_mq.c Classful multiqueue dummy scheduler
H A Dsch_prio.c2 * net/sched/sch_prio.c Simple 3-band priority "scheduler".
H A Dsch_hhf.c21 * The buckets are dequeued by a Weighted Deficit Round Robin (WDRR) scheduler,
118 /* Weighted Deficit Round Robin (WDRR) scheduler */
H A Dsch_drr.c2 * net/sched/sch_drr.c Deficit Round Robin scheduler
H A Dsch_cbq.c90 /* Link-sharing scheduler parameters */
101 /* General scheduler (WRR) parameters */
993 /* No packets in scheduler or nobody wants to give them to us :-( cbq_dequeue()
H A Dsch_choke.c2 * net/sched/sch_choke.c CHOKE scheduler
H A Dsch_pie.c564 MODULE_DESCRIPTION("Proportional Integral controller Enhanced (PIE) scheduler");
H A Dsch_fq.c22 * bunch of packets, and this packet scheduler adds delay between
H A Dsch_sfq.c60 traffic from non-interactive. It means, that this scheduler
H A Dsch_hfsc.c48 * upperlimit service curve. the link-sharing scheduler does not schedule
122 struct hfsc_sched *sched; /* scheduler data */
H A Dsch_qfq.c88 The per-scheduler-instance data contain all the data structures
89 for the scheduler: bitmaps and bucket lists.
/linux-4.4.14/arch/powerpc/platforms/cell/spufs/
H A Dsched.c1 /* sched.c - SPU scheduler.
72 * Frequency of the spu scheduler tick. By default we do one SPU scheduler
73 * tick for every 10 CPU scheduler ticks.
78 * These are the 'tuning knobs' of the scheduler:
80 * Minimum timeslice is 5 msecs (or 1 spu scheduler tick, whichever is
138 * to update its parameters, because we know that the scheduler __spu_update_sched_info()
640 * exactly fair, but so far the whole spu scheduler tries to keep find_victim()
742 from the scheduler thread or from spu_deactivate */ spu_schedule()
H A Dspufs.h122 /* scheduler fields */
/linux-4.4.14/arch/mips/include/asm/
H A Dswitch_to.h41 * Handle the scheduler resume end of FPU affinity management. We do this
H A Dprocessor.h258 /* Saved per-thread scheduler affinity mask */
/linux-4.4.14/arch/s390/numa/
H A Dnuma.c142 * topology update is called for by the scheduler.
H A Dmode_emu.c12 * Because the current Linux scheduler code requires a stable cpu to node
/linux-4.4.14/arch/nios2/include/asm/
H A Dthread_info.h55 * preempt_count needs to be 1 initially, until the scheduler is functional.
/linux-4.4.14/arch/openrisc/include/asm/
H A Dthread_info.h69 * preempt_count needs to be 1 initially, until the scheduler is functional.
/linux-4.4.14/arch/arm/mach-omap2/
H A Dsdrc.c126 * Turn on smart idle modes for SDRAM scheduler and controller.
/linux-4.4.14/arch/arm/include/asm/
H A Dmmu_context.h110 * This is the actual mm switch as far as the scheduler
/linux-4.4.14/tools/perf/bench/
H A Dsched-pipe.c8 * http://people.redhat.com/mingo/cfs-scheduler/tools/pipe-test-1m.c
H A Dfutex-wake-parallel.c86 * For now let the scheduler decide. wakeup_threads()
H A Dsched-messaging.c5 * messaging: Benchmark for scheduler and IPC mechanisms
/linux-4.4.14/drivers/staging/lustre/lnet/klnds/o2iblnd/
H A Do2iblnd_modparams.c55 /* Number of threads in each scheduler pool which is percpt,
59 MODULE_PARM_DESC(nscheds, "number of threads in each scheduler pool");
H A Do2iblnd.h75 /* # scheduler loops before reschedule */
335 int ibs_nthreads; /* number of scheduler threads */
336 int ibs_nthreads_max; /* max allowed scheduler threads */
524 struct kib_sched_info *ibc_sched; /* scheduler information */
H A Do2iblnd.c2455 /* NB: we really want to stop scheduler threads net by net kiblnd_base_shutdown()
2680 CERROR("Can't spawn thread %d for scheduler[%d]: %d\n", kiblnd_start_schedulers()
2707 CERROR("Failed to start scheduler threads for %s\n", kiblnd_dev_start_threads()
/linux-4.4.14/kernel/
H A Dlatencytop.c32 * the scheduler gets invoked. The userland tool will use this string to
163 * as called by the scheduler.
H A Dcpuset.c17 * 2008 Rework of the scheduler domains and CPU hotplug handling
572 * partition_sched_domains() routine, which will rebuild the scheduler's
725 * The rest of the code, including the scheduler, can deal with generate_sched_domains()
789 * Rebuild scheduler domains.
795 * scheduler's dynamic sched domains.
819 /* Have scheduler rebuild the domains */ rebuild_sched_domains_locked()
2342 * otherwise, the scheduler will get confused and put tasks to the cpuset_update_active_cpus()
H A Dsoftirq.c68 * to the pending events, so lets the scheduler to balance
/linux-4.4.14/arch/sparc/kernel/
H A Dsun4d_smp.c72 /* Unblock the master CPU _only_ when the scheduler state sun4d_cpu_pre_online()
75 * to call the scheduler code. sun4d_cpu_pre_online()
H A Dsmp_32.c225 /* Set this up early so that things like the scheduler can init
/linux-4.4.14/arch/arm/kernel/
H A Dtopology.c36 * and we reflect that difference in the cpu_capacity field so the scheduler
316 /* Set scheduler topology descriptor */
H A Dentry-header.S258 @ and the handlers cannot call into the scheduler (meaning the value
/linux-4.4.14/drivers/gpu/drm/amd/amdkfd/
H A Dkfd_dbgmgr.h114 * a SW object combining a user-mode provided "syncvar" and a scheduler event
121 * in the user mode instruction stream. The OS scheduler event is typically
H A Dkfd_device_queue_manager.h147 * This struct is a base class for the kfd queues scheduler in the
151 * concrete device. This class is the only class in the queues scheduler
H A Dkfd_interrupt.c31 * out to each interrupt client module (currently only the scheduler) to ask if
H A Dkfd_priv.h42 * When working with cp scheduler we should assign the HIQ manually or via
/linux-4.4.14/tools/perf/
H A Dbuiltin-bench.c12 * sched ... scheduler and IPC performance
47 { "all", "Run all scheduler benchmarks", NULL },
/linux-4.4.14/drivers/staging/lustre/lnet/klnds/socklnd/
H A Dsocklnd.h63 #define SOCKNAL_RESCHED 100 /* # scheduler loops before reschedule */
82 typedef struct /* per scheduler state */
88 wait_queue_head_t kss_waitq; /* where scheduler sleeps */
90 * this scheduler */
120 int *ksnd_nscheds; /* # scheduler threads in each
H A Dsocklnd_modparams.c48 MODULE_PARM_DESC(nscheds, "# scheduler daemons in each pool while starting");
H A Dsocklnd_cb.c534 /* enomem list takes over scheduler's ref... */ ksocknal_process_transmit()
764 /* +1 ref for scheduler */ ksocknal_queue_tx_locked()
1357 /* scheduler hasn't noticed I'm parsing yet */ ksocknal_recv()
1551 * Add connection to kss_rx_conns of scheduler
1552 * and wakeup the scheduler.
1568 /* extra ref for scheduler */ ksocknal_read_callback()
1577 * Add connection to kss_tx_conns of scheduler
1578 * and wakeup the scheduler.
1595 /* extra ref for scheduler */ ksocknal_write_callback()
H A Dsocklnd.c1449 * these TXs will be send to /dev/null by scheduler */ ksocknal_close_conn_locked()
1555 /* wake up the scheduler to "send" all remaining packets to /dev/null */ ksocknal_terminate_conn()
1566 /* extra ref for scheduler */ ksocknal_terminate_conn()
1580 * scheduler yet, but it _has_ committed to terminate... */ ksocknal_terminate_conn()
2717 CERROR("Can't spawn thread %d for scheduler[%d]: %d\n", ksocknal_start_schedulers()
/linux-4.4.14/arch/tile/include/asm/
H A Dcacheflush.h151 * On SMP systems, when the scheduler does migration-cost autodetection,
/linux-4.4.14/arch/microblaze/kernel/
H A Dptrace.c54 * (1) A register normally saved before calling the scheduler, is reg_save_addr()
H A Dentry.S410 bralid r15, schedule; /* Call scheduler */
584 /* Call the scheduler before returning from a syscall/trap. */
585 bralid r15, schedule; /* Call scheduler */
831 /* Call the scheduler before returning from a syscall/trap. */
832 bralid r15, schedule; /* Call scheduler */
/linux-4.4.14/arch/arm64/include/asm/
H A Dmmu_context.h121 * This is the actual mm switch as far as the scheduler
/linux-4.4.14/arch/arm64/kvm/
H A Dhandle_exit.c64 * WFE: Yield the CPU and come back to this vcpu when the scheduler
/linux-4.4.14/arch/arm/mach-omap1/
H A Dtime.c177 * MPU timer 2 ... free running 32-bit clock source and scheduler clock
/linux-4.4.14/arch/arm/kvm/
H A Dhandle_exit.c82 * WFE: Yield the CPU and come back to this vcpu when the scheduler
/linux-4.4.14/drivers/usb/host/
H A Du132-hcd.c172 struct delayed_work scheduler; member in struct:u132_endp
180 struct delayed_work scheduler; member in struct:u132_ring
313 if (queue_delayed_work(workqueue, &ring->scheduler, delta)) u132_ring_requeue_work()
315 } else if (queue_delayed_work(workqueue, &ring->scheduler, 0)) u132_ring_requeue_work()
329 if (cancel_delayed_work(&ring->scheduler)) u132_ring_cancel_work()
392 if (queue_delayed_work(workqueue, &endp->scheduler, delta)) u132_endp_queue_work()
398 if (cancel_delayed_work(&endp->scheduler)) u132_endp_cancel_work()
1304 container_of(work, struct u132_ring, scheduler.work); u132_hcd_ring_work_scheduler()
1367 container_of(work, struct u132_endp, scheduler.work); u132_hcd_endp_work_scheduler()
1883 INIT_DELAYED_WORK(&endp->scheduler, u132_hcd_endp_work_scheduler); create_endpoint_and_queue_int()
1982 INIT_DELAYED_WORK(&endp->scheduler, u132_hcd_endp_work_scheduler); create_endpoint_and_queue_bulk()
2078 INIT_DELAYED_WORK(&endp->scheduler, u132_hcd_endp_work_scheduler); create_endpoint_and_queue_control()
3031 INIT_DELAYED_WORK(&ring->scheduler, u132_initialise()
H A Dehci-q.c752 * For interrupt urbs, the scheduler must set the microframe scheduling
900 /* NOTE: if (PIPE_INTERRUPT) { scheduler sets c-mask } */ qh_make()
934 /* NOTE: if (PIPE_INTERRUPT) { scheduler sets s-mask } */ qh_make()
H A Dohci-hub.c623 * 3msec gap between pulses. scheduler HZ==100 must work; root_port_reset()
/linux-4.4.14/drivers/scsi/isci/
H A Dport.c539 * This structure will be posted to the hardware to work around a scheduler
567 * structure will be posted to the hardwre to work around a scheduler error
878 * Prevent the hardware scheduler from posting new requests to the front
879 * of the scheduler queue causing a starvation problem for currently
928 * This method will resume the port task scheduler for this port object. none
1021 * the port not ready and suspends the port task scheduler. none
1442 /* enable the port task scheduler in a suspended state */ sci_port_enable_port_task_scheduler()
1494 * task scheduler. */ sci_port_stopped_state_enter()
1503 /* Enable and suspend the port task scheduler */ sci_port_stopped_state_exit()
H A Dport.h92 * @reserved_rni: reserver for port task scheduler workaround
/linux-4.4.14/drivers/net/ethernet/chelsio/cxgb/
H A Dsge.c223 /* T204 TX SW scheduler */
241 struct tasklet_struct sched_tsk;/* tasklet used to run scheduler */
295 * re-computes scheduler parameters to scope with the change.
340 * t1_sched_max_avail_bytes() tells the scheduler the maximum amount of
354 * t1_sched_set_drain_bits_per_us() tells the scheduler at which rate a port
428 * The scheduler only returns a skb (which will then be sent) if the
1302 * Called from tasklet. Checks the scheduler for any
1697 * through the scheduler. t1_sge_tx()
1702 /* Note that the scheduler might return a different skb than t1_sge_tx()
/linux-4.4.14/drivers/usb/serial/
H A Dkeyspan_pda.c180 /* queue up a wakeup at scheduler time */ keyspan_pda_rx_interrupt()
475 scheduler time, since usb_control_msg() sleeps. */ keyspan_pda_write()
557 /* queue up a wakeup at scheduler time */ keyspan_pda_write_bulk_callback()
/linux-4.4.14/init/
H A Dmain.c562 * Set up the scheduler prior starting any interrupts (such as the start_kernel()
564 * time - but meanwhile we still have a functioning scheduler. start_kernel()
984 /* Now the scheduler is fully set up and can do blocking allocations */ kernel_init_freeable()
/linux-4.4.14/kernel/sched/
H A Dcputime.c66 * in that case, so as not to confuse scheduler with a special task irqtime_account_irq()
559 * Adjust tick based cputime random precision against scheduler runtime
569 * accounted by the CFS scheduler.
H A Dstats.h162 * The following are functions that support scheduler-internal time accounting.
H A Dcore.c4 * Kernel scheduler and related syscalls
12 * 2002-01-04 New ultra-scalable O(1) scheduler by Ingo Molnar:
571 * might also involve a cross-CPU call to trigger the scheduler on
722 * tasks are of a lower priority. The scheduler tick does nothing. sched_can_stop_tick()
976 * taken into account by the scheduler. This value might
1101 * So we race with normal scheduler movements, but that's OK, as long
2029 * disabled avoiding further scheduler activity on it and we've try_to_wake_up_local()
2095 * Perform scheduler related setup for a newly forked process p.
2368 * This function will do some initial scheduler statistics housekeeping
2696 * of the scheduler it's an obvious special-case), so we context_switch()
2712 * externally visible scheduler statistics: current number of runnable
2890 * active task is running because the scheduler doesn't
3012 panic("corrupted stack end detected inside scheduler\n"); schedule_debug()
3066 * __schedule() is the main scheduler function.
3068 * The main means of driving the scheduler and thus entering this function are:
3075 * To drive preemption between tasks, the scheduler sets the flag in timer
3288 * can occur before user_exit() is called. This will cause the scheduler
3293 * calling the scheduler.
3974 * normal parameters and do not touch the scheduler class and __sched_setscheduler()
4181 * sys_sched_setscheduler - set/change the scheduler policy and RT priority
4673 * The scheduler is at all times free to pick the calling task as the most
7085 * Set up scheduler domains and groups. Callers must hold the hotplug lock.
H A Dfair.c142 * This idea comes from the SD scheduler of Con Kolivas:
1466 * Cpusets can break the scheduler domain tree into smaller task_numa_migrate()
1696 * NUMA placement cycle. The scheduler keeps similar statistics, but
1698 * from the dozens-of-seconds NUMA balancing period. Use the scheduler
2120 * case it previously failed, or the scheduler moved us. task_numa_fault()
4311 * scheduler tick (TICK_NSEC). With tickless idle this will not be called
4903 * migrations (scheduler-driven DVFS).
5308 * further scheduler activity on it and we're being very careful to pick_next_task_fair()
5386 /* Tell the scheduler that we'd really like pse to run next. */ yield_to_task_fair()
5401 * per-cpu scheduler provides, namely provide a proportional amount of compute
7679 * rebalancing for all the cpus for whom scheduler ticks are stopped.
7743 * - At parent of LLC scheduler domain level, this cpu's scheduler group has
7745 * - For SD_ASYM_PACKING, if the lower numbered cpu's in the scheduler
7817 * run_rebalance_domains is triggered when needed from the scheduler tick. nohz_idle_balance()
7873 * scheduler tick hitting a task of our scheduling class:
H A Ddeadline.c339 * entity wants to (try to!) synchronize its behaviour with the scheduler's
440 * Documentation/scheduler/sched-deadline.txt for more informations).
1167 * disabled avoiding further scheduler activity on it and we're pick_next_task_dl()
/linux-4.4.14/drivers/net/
H A Deql.c87 * with the dumber scheduler
96 * scheduler was torn out and replaced with something smarter
/linux-4.4.14/include/trace/events/
H A Dsched.h122 * Tracepoint for task switches, performed by the scheduler:
347 * but not actually running due to scheduler contention).
/linux-4.4.14/drivers/staging/rtl8723au/include/
H A DHal8723PwrSeq.h99 {0x0553, PWR_CUT_ALL_MSK, PWR_FAB_ALL_MSK, PWR_INTF_ALL_MSK, PWR_BASEADDR_MAC, PWR_CMD_WRITE, BIT(5), BIT(5)},/*Respond TxOK to scheduler*/
/linux-4.4.14/drivers/isdn/hysdn/
H A Dhysdn_sched.c4 * scheduler routines for handling exchange card <-> pc.
H A Dhysdn_defs.h178 /* scheduler for data transfer (only async parts) */
/linux-4.4.14/drivers/net/wireless/realtek/rtlwifi/rtl8188ee/
H A Dpwrseq.h225 /*Respond TxOK to scheduler*/},
/linux-4.4.14/drivers/net/wireless/realtek/rtlwifi/rtl8723ae/
H A Dpwrseq.h243 /*Respond TxOK to scheduler*/ \
/linux-4.4.14/arch/tile/kernel/
H A Dsmpboot.c256 * isolated from the scheduler, to keep init away from likely smp_cpus_done()
/linux-4.4.14/arch/um/kernel/
H A Dprocess.c390 /* Ignore everything until we're above the scheduler */ get_wchan()
/linux-4.4.14/net/core/
H A Dgen_estimator.c49 So I preferred not to built an estimator into the scheduler,
/linux-4.4.14/arch/powerpc/kernel/
H A Dtau_6xx.c10 * Silly, crazy ideas: use cpu load (from scheduler) and ICTC to extend battery
/linux-4.4.14/arch/hexagon/kernel/
H A Dprocess.c155 * is an identification of the point at which the scheduler
H A Dvm_entry.S280 * If we were in kernel mode, we don't need to check scheduler
/linux-4.4.14/arch/arm64/kernel/
H A Dtopology.c109 * scheduler with a flat list of them. parse_cluster()
/linux-4.4.14/drivers/net/wireless/realtek/rtlwifi/rtl8821ae/
H A Dpwrseq.h285 /*Respond TxOK to scheduler*/},
642 /*Respond TxOK to scheduler*/},
/linux-4.4.14/drivers/net/wireless/iwlwifi/mvm/
H A Dfw-api-tx.h608 * struct iwl_scd_txq_cfg_cmd - New txq hw scheduler config command
612 * @scd_queue: scheduler queue to confiug
/linux-4.4.14/drivers/net/wireless/iwlwifi/pcie/
H A Dinternal.h297 * @scd_base_addr: scheduler sram base address in SRAM
298 * @scd_bc_tbls: pointer to the byte count table of the scheduler
/linux-4.4.14/drivers/gpu/drm/i915/
H A Dintel_guc_loader.c150 * GuC ARAT increment is 10 ns. GuC default scheduler quantum is one set_guc_init_params()
179 /* Unmask this bit to enable the GuC's internal scheduler */ set_guc_init_params()
/linux-4.4.14/arch/x86/kernel/cpu/
H A Dperf_event.h278 * The event scheduler may not select the correct counter in the first
281 * overlap flag for such constraints to give the scheduler a hint which
/linux-4.4.14/kernel/time/
H A Dtime.c705 * for scheduler, not for use in device drivers to calculate timeout value.
736 * for scheduler, not for use in device drivers to calculate timeout value.
H A Dtick-sched.c643 /* Limit the tick delta to the maximum scheduler deferment */ tick_nohz_stop_sched_tick()
666 * the scheduler tick in nohz_restart_sched_tick. tick_nohz_stop_sched_tick()
827 * Update the idle state in the scheduler domain hierarchy tick_nohz_idle_enter()
/linux-4.4.14/drivers/staging/rtl8188eu/include/
H A Dpwrseq.h265 /*Respond TxOK to scheduler*/
/linux-4.4.14/drivers/net/wireless/realtek/rtlwifi/rtl8192ee/
H A Dpwrseq.h247 /*Respond TxOK to scheduler*/ \
/linux-4.4.14/drivers/net/ethernet/sfc/
H A Defx.h268 * TX scheduler is stopped when we're done and before efx_device_detach_sync()
/linux-4.4.14/drivers/net/ethernet/chelsio/cxgb4/
H A Dcxgb4_uld.h262 /* scheduler queue */
/linux-4.4.14/drivers/power/
H A Dltc2941-battery-gauge.c63 struct delayed_work work; /* Work scheduler */
/linux-4.4.14/arch/x86/include/asm/
H A Dthread_info.h160 * preempt_count needs to be 1 initially, until the scheduler is functional.
H A Dprocessor.h767 * What is this good for? it will be always the scheduler or ret_from_fork.
/linux-4.4.14/arch/arc/kernel/
H A Dentry.S44 ; put last task in scheduler queue
/linux-4.4.14/include/net/irda/
H A Dirlap.h64 * the flow control mechanism (via scheduler and IrTTP).
/linux-4.4.14/net/ipv4/
H A Dtcp_cong.c4 * Based on ideas from I/O scheduler support and Web100.
/linux-4.4.14/fs/fscache/
H A Dobject.c42 * to the scheduler first.
62 * scheduler if none of the events in which the wait state has an interest are
836 * If we don't manage to finish the list before the scheduler wants to run
/linux-4.4.14/drivers/usb/dwc2/
H A Dcore.h350 * @uframe_sched: True to enable the microframe scheduler
652 * @frame_usecs: Internal variable used by the microframe scheduler
666 * scheduler to use
H A Dhcd_queue.c324 * Microframe scheduler
/linux-4.4.14/drivers/net/ethernet/intel/i40evf/
H A Di40e_adminq_cmd.h185 /* TX scheduler */
832 /* scheduler section */
1340 /* TX scheduler 0x04xx */
/linux-4.4.14/drivers/scsi/lpfc/
H A Dlpfc_sli.h67 #define LPFC_IO_FABRIC 0x10 /* Iocb send using fabric scheduler */
H A Dlpfc_crtn.h407 /* Interface exported by fabric iocb scheduler */
/linux-4.4.14/drivers/media/usb/tm6000/
H A Dtm6000-input.c223 * So, use the scheduler to do it, in a few ms. tm6000_ir_urb_received()
/linux-4.4.14/drivers/net/wireless/realtek/rtlwifi/rtl8723be/
H A Dpwrseq.h330 /*Respond TxOK to scheduler*/ \
/linux-4.4.14/drivers/clocksource/
H A Dexynos_mct.c193 * as notrace so it can be used by the scheduler clock.
/linux-4.4.14/drivers/cpuidle/
H A Dcpuidle.c308 * Make sure external observers (such as the scheduler) cpuidle_uninstall_idle_handler()
/linux-4.4.14/mm/
H A Dswap_state.c344 * scheduler here, if there are some more important __read_swap_cache_async()
/linux-4.4.14/fs/xfs/
H A Dxfs_filestream.c60 * - The work queue scheduler fires and pulls a filestream directory cache
/linux-4.4.14/arch/ia64/include/asm/
H A Dbitops.h9 * O(1) scheduler patch
/linux-4.4.14/arch/ia64/mm/
H A Dtlb.c88 * with O(1) scheduler [EF] wrap_mmu_context()
/linux-4.4.14/drivers/scsi/
H A Dppa.c600 /* If not, drop back down to the scheduler and wait a timer tick */ ppa_completion()
609 * the scheduler's task queue to generate a stream of call-backs and
H A Dimm.c704 /* If not, drop back down to the scheduler and wait a timer tick */ imm_completion()
713 * the scheduler's task queue to generate a stream of call-backs and
/linux-4.4.14/drivers/net/ethernet/freescale/
H A Ducc_geth.h115 #define TEMODER_SCHEDULER_ENABLE 0x2000 /* enable scheduler */
574 u32 schedulerbasepointer; /* a base pointer to scheduler memory
H A Ducc_geth.c2608 /* scheduler exists only if more than 1 tx queue */ ucc_geth_startup()
2626 /* Set values in scheduler */ ucc_geth_startup()
2640 /* Set pointers to cpucount registers in scheduler */ ucc_geth_startup()
3150 count to the scheduler PRAM. */ ucc_geth_start_xmit()
/linux-4.4.14/net/sunrpc/
H A Dsched.c716 * This is the RPC `scheduler' (or rather, the finite state machine).
804 * User-visible entry point to the scheduler.
/linux-4.4.14/security/
H A Dcommoncap.c828 * cap_task_setscheduler - Detemine if scheduler policy change is permitted
831 * Detemine if the requested scheduler policy change is permitted for the
/linux-4.4.14/kernel/rcu/
H A Dupdate.c535 * after the scheduler if fully operational.
591 /* Complain if the scheduler has not started. */ synchronize_rcu_tasks()
H A Dtree.c146 * during the early_initcall() processing, which is after the scheduler
294 * Let the RCU core know that this CPU has gone through the scheduler,
1021 * the fact that a CPU enters the scheduler after completing the CPU_DYING
1164 resched_cpu(rdp->cpu); /* Force CPU into scheduler. */ rcu_implicit_dynticks_qs()
1168 resched_cpu(rdp->cpu); /* Force CPU into scheduler. */ rcu_implicit_dynticks_qs()
2753 trace_rcu_utilization(TPS("Start scheduler-tick")); rcu_check_callbacks()
2788 trace_rcu_utilization(TPS("End scheduler-tick")); rcu_check_callbacks()
4346 * This function is invoked towards the end of the scheduler's initialization
4589 * or the scheduler are operational. rcu_init()
H A Dtree_plugin.h279 * We have entered the scheduler, and the current task might soon be
1289 * Spawn boost kthreads -- called as soon as the scheduler is running.
1908 /* Having no rcuo kthread but CBs after scheduler starts is bad! */ rcu_nocb_cpu_needs_barrier()
2433 * Once the scheduler is running, spawn rcuo kthreads for all online
/linux-4.4.14/drivers/net/ethernet/intel/i40e/
H A Di40e_adminq_cmd.h185 /* TX scheduler */
835 /* scheduler section */
1343 /* TX scheduler 0x04xx */
/linux-4.4.14/drivers/hwspinlock/
H A Dhwspinlock_core.c106 * problems with hwspinlock usage (e.g. scheduler checks like __hwspin_trylock()
/linux-4.4.14/drivers/mfd/
H A Dmax8925-core.c852 /* enaable ADC scheduler, interval is 1 second */ max8925_device_init()
/linux-4.4.14/drivers/net/ethernet/intel/igb/
H A De1000_regs.h142 #define E1000_RTTBCNRM 0x3690 /* Tx BCN Rate-scheduler MMW */
/linux-4.4.14/drivers/net/wireless/ath/ath10k/
H A Dwmi-tlv.h1586 * @WMI_TLV_TX_PAUSE_ID_MCC: used for by multi-channel firmware scheduler.
H A Dwmi.h2729 /* Scan Priority, input to scan scheduler */
4532 * scheduler air time limit for this VDEV. used by off chan
4533 * scheduler.
4663 * scheduler air time limit for this VDEV. used by off chan
4664 * scheduler.
/linux-4.4.14/drivers/net/wireless/ath/ath5k/
H A Dqcu.c44 * based on TSF etc), DCU adds backoff, IFSes etc and then a scheduler
/linux-4.4.14/drivers/net/wireless/ath/
H A Dregd.c512 * a world regulatory domain and the scheduler hasn't yet processed ath_reg_notifier_apply()
/linux-4.4.14/drivers/dma/
H A Dcppi41.c39 /* DMA scheduler */
/linux-4.4.14/arch/x86/kernel/
H A Dreboot.c625 * scheduler's load balance. native_machine_shutdown()
/linux-4.4.14/arch/x86/kvm/
H A Di8254.c362 * scheduler. create_pit_timer()
/linux-4.4.14/fs/cifs/
H A Dnterr.h561 #define NT_STATUS_NO_SUCH_JOB 0xC0000000 | 0xEDE /* scheduler */
/linux-4.4.14/include/crypto/
H A Dskcipher.h159 * load-balanced on the different CPUs via the process scheduler. To allow
/linux-4.4.14/arch/s390/mm/
H A Dfault.c702 * before the scheduler is reached. */ pfault_interrupt()
/linux-4.4.14/drivers/net/wireless/iwlwifi/dvm/
H A Dcommands.h226 * because the ucode will stop/start the scheduler as
990 * When using full FIFO flush this command checks the scheduler HW block WR/RD
999 * the flush operation ends when both the scheduler DMA done and TXFIFO empty
1136 * SCD registers and Tx/Rx Queues). When the device's Tx scheduler and uCode
1142 * (RTS/CTS/ACK), based on flags in the Tx command. uCode and Tx scheduler
1604 * (scheduler will then try to tx it as single frame).
/linux-4.4.14/drivers/block/
H A Dpktcdvd.c27 * The lowest layer in the packet writing driver is the packet I/O scheduler.
37 * packet I/O scheduler.
43 * them to the packet I/O scheduler.
/linux-4.4.14/kernel/printk/
H A Dprintk.c239 * within the scheduler's rq lock. It must be released before calling
1808 /* If called from the scheduler, we can not call up(). */ vprintk_emit()
2710 * Delayed printk version, for scheduler-internal messages:

Completed in 6738 milliseconds

12