Home
last modified time | relevance | path

Searched +full:queue +full:- +full:tick (Results 1 – 25 of 131) sorted by relevance

123456

/external/kernel-headers/original/uapi/sound/
Dasequencer.h1 /* SPDX-License-Identifier: GPL-2.0+ WITH Linux-syscall-note */
4 * Copyright (c) 1998-1999 by Frank van de Pol <fvdpol@coil.demon.nl>
5 * (c) 1998-1999 by Jaroslav Kysela <perex@perex.cz>
39 #define SNDRV_SEQ_EVENT_PITCHBEND 13 /**< from -8192 to 8191 */
59 #define SNDRV_SEQ_EVENT_SETPOS_TICK 33 /* set tick queue position */
60 #define SNDRV_SEQ_EVENT_SETPOS_TIME 34 /* set realtime queue position */
63 #define SNDRV_SEQ_EVENT_TICK 37 /* midi Real Time Tick message */
64 #define SNDRV_SEQ_EVENT_QUEUE_SKEW 38 /* skew queue tempo */
70 #define SNDRV_SEQ_EVENT_RESET 41 /* reset to power-on state */
95 /* 70-89: synthesizer events - obsoleted */
[all …]
/external/rust/crates/tokio/src/task/
Dlocal.rs151 /// pub fn new() -> Self {
219 /// Current scheduler tick.
220 tick: Cell<u8>,
222 /// State available from thread-local.
230 /// State available from the thread-local.
248 /// Remote run queue sender.
249 queue: Mutex<Option<VecDeque<task::Notified<Arc<Shared>>>>>, field
265 /// Local run queue sender and receiver.
332 pub fn spawn_local<F>(future: F) -> JoinHandle<F::Output>
342 pub(super) fn spawn_local_inner<F>(future: F, name: Option<&str>) -> JoinHandle<F::Output>
[all …]
/external/blktrace/btt/
Dbtt_plot.py5 # (C) Copyright 2009 Hewlett-Packard Development Company, L.P.
19 # Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307 USA
26 AQD - Average Queue Depth Running average of queue depths
28 BNOS - Block numbers accessed Markers for each block
30 Q2D - Queue to Issue latencies Running averages
31 D2C - Issue to Complete latencies Running averages
32 Q2C - Queue to Complete latencies Running averages
35 btt_plot_aqd.py equivalent to: btt_plot.py -t aqd <type>=aqd
36 btt_plot_bnos.py equivalent to: btt_plot.py -t bnos <type>=bnos
37 btt_plot_q2d.py equivalent to: btt_plot.py -t q2d <type>=q2d
[all …]
/external/rust/crates/tokio/src/runtime/scheduler/current_thread/
Dmod.rs49 /// Scheduler run queue
52 /// Current tick
53 tick: u32, field
63 /// How often to check the global queue
73 /// Remote run queue
92 /// Thread-local context.
109 /// Initial queue capacity.
113 /// as we unify tuning logic between the multi-thread and current-thread
124 ) -> (CurrentThread, Arc<Handle>) { in new()
127 // Get the configured global queue interval, or use the default. in new()
[all …]
/external/grpc-grpc/test/core/event_engine/fuzzing_event_engine/
Dfuzzing_event_engine.h7 // http://www.apache.org/licenses/LICENSE-2.0
24 #include <queue>
69 void Tick(Duration max_time = std::chrono::seconds(600))
71 // Repeatedly call Tick() until there is no more work to do.
73 // Tick until some time
75 // Tick for some duration
143 // may be iterated through and inspected - principally to discover the ports
204 std::queue<size_t> write_sizes[2] ABSL_GUARDED_BY(mu_);
208 // Helper to take some bytes from data and queue them into pending[index].
214 // When a connection is formed, we create two of these - one with index 0, the
[all …]
/external/rust/crates/tokio/src/runtime/scheduler/multi_thread/
Dworker.rs3 //! run queue and other state. When `block_in_place` is called, the worker's
11 //! 1. The Shared::close method is called. This closes the inject queue and
15 //! Core::maintenance by checking whether the inject queue is closed.
23 //! 5. The workers call Shared::shutdown to enter the single-threaded phase of
27 //! 6. The local run queue of each core is emptied, then the inject queue is
38 //! * The spawner observes the OwnedTasks being open, and the inject queue is
41 //! inject queue.
50 //! The correctness of shutdown requires both the inject queue and OwnedTasks
51 //! collection to have a closed bit. With a close bit on only the inject queue,
55 //! to the inject queue after step 6 of shutdown, which would leave a task in
[all …]
/external/webrtc/api/metronome/test/
Dfake_metronome.h4 * Use of this source code is governed by a BSD-style license
29 // ForcedTickMetronome is a Metronome that ticks when `Tick()` is invoked.
36 void Tick();
52 // `Stop()` must be called before destruction, as it cancels the metronome tick
53 // on the proper task queue.
/external/perfetto/infra/ci/controller/
Dcron.yaml7 # http://www.apache.org/licenses/LICENSE-2.0
15 - description: "Run postsubmits"
20 - description: "Logs cleanup"
25 - description: "Delete stale jobs from the running queue"
31 # /worker/tick task enqueues the next one. However if anything goes wrong the
32 # chain would break. We use this cron job to re-kick it if this happens.
33 - description: "Gerrit poller failsafe"
34 url: /controller/tick
Dcontroller.py7 # http://www.apache.org/licenses/LICENSE-2.0
42 # ------------------------------------------------------------------------------
44 # ------------------------------------------------------------------------------
48 '''Appends a task to the deferred queue.
52 - Auditability in logs: it's easier to scrape logs and debug.
53 - Stability: an exception fails only the current task not the whole function.
54 - Reliability: The AppEngine runtime will retry failed tasks with exponential
56 - Performance: tasks are run concurrently, which is quite important given that
60 queue_name='deferred-jobs',
107 # ------------------------------------------------------------------------------
[all …]
Dqueue.yaml7 # http://www.apache.org/licenses/LICENSE-2.0
14 queue:
15 - name: tick
21 - name: deferred-jobs
/external/cronet/base/test/
Dtest_mock_time_task_runner.h2 // Use of this source code is governed by a BSD-style license that can be
11 #include <queue>
37 // track of a mock (virtual) tick clock time that can be fast-forwarded.
41 // - Methods RunsTasksInCurrentSequence() and Post[Delayed]Task() can be
46 // - It allows for reentrancy, in that it handles the running of tasks that in
48 // - Tasks are stored in a priority queue, and executed in the increasing
50 // - It does not check for overflow when doing time arithmetic. A sufficient
52 // posted task delays and fast-forward increments is still representable by
58 // - Thread/SequencedTaskRunner::CurrentDefaultHandle refers to it on its
60 // - It can be driven by a RunLoop on the thread it was created on.
[all …]
/external/skia/src/gpu/graphite/dawn/
DDawnQueueManager.h4 * Use of this source code is governed by a BSD-style license that can be
22 DawnQueueManager(wgpu::Queue, const SharedContext*);
25 const wgpu::Queue& dawnQueue() const { return fQueue; } in dawnQueue()
27 void tick() const override;
40 wgpu::Queue fQueue;
DDawnQueueManager.cpp4 * Use of this source code is governed by a BSD-style license that can be
38 queueManager->dawnQueue().OnSubmittedWorkDone( in DawnWorkSubmissionWithAsyncWait()
41 // https://github.com/webgpu-native/webgpu-headers/issues/130 in DawnWorkSubmissionWithAsyncWait()
46 asyncWaitPtr->signal(); in DawnWorkSubmissionWithAsyncWait()
78 fSubmittedWorkDoneFuture = queueManager->dawnQueue().OnSubmittedWorkDone( in DawnWorkSubmissionWithFuture()
86 ->device() in onIsFinished()
100 ->device() in onWaitUntilFinished()
113 DawnQueueManager::DawnQueueManager(wgpu::Queue queue, const SharedContext* sharedContext) in DawnQueueManager() argument
114 : QueueManager(sharedContext), fQueue(std::move(queue)) {} in DawnQueueManager()
116 void DawnQueueManager::tick() const { this->dawnSharedContext()->tick(); } in tick() function in skgpu::graphite::DawnQueueManager
[all …]
DDawnSharedContext.h4 * Use of this source code is governed by a BSD-style license that can be
31 const DawnCaps* dawnCaps() const { return static_cast<const DawnCaps*>(this->caps()); } in dawnCaps()
33 const wgpu::Queue& queue() const { return fQueue; } in queue() function
38 void tick() const { in tick() function
39 SkASSERT(this->hasTick()); in tick()
50 wgpu::Queue fQueue;
/external/webrtc/api/metronome/
Dmetronome.h4 * Use of this source code is governed by a BSD-style license
21 // The API is designed to be fully used from a single task queue. Scheduled
30 // Metronome implementations must be thread-compatible.
35 // Requests a call to `callback` on the next tick. Scheduled callbacks are
41 // Returns the current tick period of the metronome.
/external/openthread/third_party/tcplp/bsdtcp/
Dtcp_var.h1 /*-
55 /* Implement byte-order-specific functions using OpenThread. */
110 * including sys/queue.h from this file. It's undesirable to include
111 * sys/queue.h from this file because this file is part of the external
112 * interface to TCPlp, and sys/queue.h pollutes the global namespace.
148 #define tpcantrcvmore(tp) (tp)->miscflags |= TCB_CANTRCVMORE
149 #define tpcantsendmore(tp) (tp)->miscflags |= TCB_CANTSENDMORE
150 #define tpiscantrcv(tp) (((tp)->miscflags & TCB_CANTRCVMORE) != 0)
151 #define tpiscantsend(tp) (((tp)->miscflags & TCB_CANTSENDMORE) != 0)
152 #define tpmarktimeractive(tp, timer) (tp)->miscflags |= timer
[all …]
/external/rust/crates/tokio/src/runtime/tests/
Dtask.rs28 fn new() -> (Self, AssertDropHandle) { in new()
46 // A Notified does not shut down on drop, but it is dropped once the ref-count
170 assert_eq!(2, rt.tick()); in schedule()
246 queue: VecDeque::new(), in with()
263 queue: VecDeque<task::Notified<Runtime>>, field
269 fn spawn<T>(&self, future: T) -> JoinHandle<T::Output> in spawn()
283 fn tick(&self) -> usize { in tick() method
287 fn tick_max(&self, max: usize) -> usize { in tick_max()
300 fn is_empty(&self) -> bool { in is_empty()
301 self.0.core.try_lock().unwrap().queue.is_empty() in is_empty()
[all …]
/external/python/httplib2/tests/
D__init__.py24 from six.moves import http_client, queue
147 content_length_string = msg.headers.get("content-length", "")
151 elif msg.headers.get("transfer-encoding") == "chunked":
282 :param fun: fun(client_sock, tick) called after successful accept().
283 …:param request_count: test succeeds after exactly this number of requests, triggered by tick(reque…
286 "" - build normal http/https URI.
287 string - build normal URI using supplied scheme.
288 None - yield (addr, port) tuple.
290 None (default) - plain HTTP.
291 … True - HTTPS with reasonable defaults. Likely you want httplib2.Http(ca_certs=tests.CA_CERTS)
[all …]
/external/rust/crates/tokio/src/runtime/io/
Ddriver.rs23 tick: u8, field
31 /// The system event queue.
56 pub(super) tick: u8, field
63 pub(crate) fn with_ready(&self, ready: Ready) -> Self {
66 tick: self.tick,
79 pub(super) enum Tick { enum
98 pub(crate) fn new(nevents: usize) -> io::Result<(Driver, Handle)> { in new()
105 tick: 0, in new()
148 self.tick = self.tick.wrapping_add(1); in turn()
187 io.set_readiness(Tick::Set(self.tick), |curr| curr | ready); in turn()
[all …]
/external/sonivox/jet_tools/JetCreator/
DJetCreatorhlp.dat14 starting m/b/t = Sets the starting measure, beat, and tick for the event.
22 un-mute =
28 ending m/b/t = Sets the ending measure, beat, and tick for the segment.
55 starting m/b/t = Sets the starting measure, beat, and tick for the segment.
60 transpose = Sets the transposition value for the segment, in semitones (half-steps).
67 ending m/b/t = Sets the ending measure, beat, and tick for the segment.
101 …e JET file display here. Double click on a segment to add it to the play queue, or use the button…
/external/libchrome/base/test/
Dtest_mock_time_task_runner.h2 // Use of this source code is governed by a BSD-style license that can be
11 #include <queue>
33 // track of a mock (virtual) tick clock time that can be fast-forwarded.
37 // - Methods RunsTasksInCurrentSequence() and Post[Delayed]Task() can be
40 // - It allows for reentrancy, in that it handles the running of tasks that in
42 // - Tasks are stored in a priority queue, and executed in the increasing
44 // - It does not check for overflow when doing time arithmetic. A sufficient
46 // posted task delays and fast-forward increments is still representable by
52 // - Thread/SequencedTaskRunnerHandle refers to it on its thread.
53 // - It can be driven by a RunLoop on the thread it was created on.
[all …]
/external/rust/crates/tokio/src/runtime/scheduler/multi_thread_alt/
Dworker.rs3 //! run queue and other state. When `block_in_place` is called, the worker's
11 //! 1. The Shared::close method is called. This closes the inject queue and
15 //! Core::maintenance by checking whether the inject queue is closed.
23 //! 5. The workers call Shared::shutdown to enter the single-threaded phase of
27 //! 6. The local run queue of each core is emptied, then the inject queue is
38 //! * The spawner observes the OwnedTasks being open, and the inject queue is
41 //! inject queue.
50 //! The correctness of shutdown requires both the inject queue and OwnedTasks
51 //! collection to have a closed bit. With a close bit on only the inject queue,
55 //! to the inject queue after step 6 of shutdown, which would leave a task in
[all …]
/external/OpenCL-CTS/test_conformance/profiling/
Dmain.cpp8 // http://www.apache.org/licenses/LICENSE-2.0
63 // FIXME: use timer resolution rather than hardcoding 1µs per tick.
78 double queueTosubmitTimeS = (double)(commandSubmit - queueStart)*1e-9; in check_times()
79 double submitToStartTimeS = (double)(commandStart - commandSubmit)*1e-9; in check_times()
80 double startToEndTimeS = (double)(commandEnd - commandStart)*1e-9; in check_times()
83 log_info( "Time from queue to submit : %fms\n", (double)(queueTosubmitTimeS) * 1000.f ); in check_times()
89 err = -1; in check_times()
94 err = -1; in check_times()
99 err = -1; in check_times()
104 err = -1; in check_times()
[all …]
/external/ltp/testcases/kernel/sound/
Dsnd_seq01.c1 // SPDX-License-Identifier: GPL-2.0-or-later
6 * CVE-2018-7566
26 static int fd = -1;
33 .queue = 0,
35 .time = { .tick = 10 }
64 struct snd_seq_queue_info qconf = { .queue = 0 }; in setup()
69 if (fd == -1 && (errno == ENOENT || errno == EACCES)) in setup()
129 {"linux-git", "d15d662e89fc"},
130 {"CVE", "2018-7566"},
/external/rust/crates/tokio/src/runtime/time/
Dentry.rs17 //! between threads without an acq/rel barrier, and same-thread we have local
18 //! happens-before ordering).
24 //! This state can either indicate that the timer is on the 'pending' queue (and
35 //! lock-free timer resets, in the case where a timer is rescheduled to a later
52 //! [`mark_pending`][mark_pending] performs a compare-and-swap, it will identify this race and
73 const STATE_PENDING_FIRE: u64 = STATE_DEREGISTERED - 1;
78 pub(super) const MAX_SAFE_MILLIS_DURATION: u64 = u64::MAX - 2;
80 /// This structure holds the current shared state of the timer - its scheduled
100 /// The currently-registered waker
105 fn default() -> Self { in default()
[all …]

123456