Home
last modified time | relevance | path

Searched full:writer (Results 1 – 25 of 418) sorted by relevance

12345678910>>...17

/openbmc/qemu/qobject/
H A Djson-writer.c2 * JSON Writer
17 #include "qapi/qmp/json-writer.h"
29 JSONWriter *writer = g_new(JSONWriter, 1); in json_writer_new() local
31 writer->pretty = pretty; in json_writer_new()
32 writer->need_comma = false; in json_writer_new()
33 writer->contents = g_string_new(NULL); in json_writer_new()
34 writer->container_is_array = g_byte_array_new(); in json_writer_new()
35 return writer; in json_writer_new()
38 const char *json_writer_get(JSONWriter *writer) in json_writer_get() argument
40 g_assert(!writer->container_is_array->len); in json_writer_get()
[all …]
H A Dqjson.c17 #include "qapi/qmp/json-writer.h"
151 static void to_json(JSONWriter *writer, const char *name, in to_json() argument
156 json_writer_null(writer, name); in to_json()
163 json_writer_int64(writer, name, val->u.i64); in to_json()
166 json_writer_uint64(writer, name, val->u.u64); in to_json()
169 json_writer_double(writer, name, val->u.dbl); in to_json()
179 json_writer_str(writer, name, qstring_get_str(val)); in to_json()
186 json_writer_start_object(writer, name); in to_json()
191 to_json(writer, qdict_entry_key(entry), qdict_entry_value(entry)); in to_json()
194 json_writer_end_object(writer); in to_json()
[all …]
/openbmc/openbmc/poky/scripts/pybootchartgui/pybootchartgui/tests/
H A Dparser_test.py18 writer = main._mk_writer(options) variable
30 trace = parsing.Trace(writer, args, options)
31 state = parsing.parse_file(writer, trace, self.mk_fname('header'))
36 trace = parsing.Trace(writer, args, options)
37 state = parsing.parse_file(writer, trace, self.mk_fname('proc_diskstats.log'))
41 trace = parsing.Trace(writer, args, options)
42 state = parsing.parse_file(writer, trace, self.mk_fname('proc_ps.log'))
63 trace = parsing.Trace(writer, args, options)
64 state_with_headers = parsing.parse_file(writer, trace, self.mk_fname('header'))
66 …samples = parsing.parse_file(writer, state_with_headers, self.mk_fname('proc_diskstats.log')).disk…
[all …]
H A Dprocess_tree_test.py22 writer = main._mk_writer(options)
23 trace = parsing.Trace(writer, args, options)
25 parsing.parse_file(writer, trace, self.mk_fname('proc_ps.log'))
26 trace.compile(writer)
27 self.processtree = process_tree.ProcessTree(writer, None, trace.ps_stats, \
/openbmc/openbmc/poky/bitbake/lib/bb/asyncrpc/
H A Dconnection.py41 def __init__(self, reader, writer, timeout, max_chunk=DEFAULT_MAX_CHUNK): argument
43 self.writer = writer
49 return self.writer.get_extra_info("peername")
53 self.writer.write(c.encode("utf-8"))
54 await self.writer.drain()
76 self.writer.write(("%s\n" % msg).encode("utf-8"))
77 await self.writer.drain()
100 if self.writer is not None:
101 self.writer.close()
102 self.writer = None
/openbmc/linux/Documentation/trace/
H A Dring-buffer-design.rst28 - the task that writes into the ring buffer (same as writer)
30 writer
81 but a writer may interrupt another writer, but it must finish writing
82 before the previous writer may continue. This is very important to the
94 This is very much like a writer being preempted by an interrupt and
99 cannot preempt/interrupt a writer, but it may read/consume from the
100 buffer at the same time as a writer is writing, but the reader must be
102 and can be preempted by a writer.
104 A writer can preempt a reader, but a reader cannot preempt a writer.
106 as a writer.
[all …]
/openbmc/linux/kernel/locking/
H A Dpercpu-rwsem.c22 rcuwait_init(&sem->writer); in __percpu_init_rwsem()
57 * If the reader misses the writer's assignment of sem->block, then the in __percpu_down_read_trylock()
58 * writer is guaranteed to see the reader's increment. in __percpu_down_read_trylock()
61 * the writer looks are guaranteed to see the sem->block value, which in __percpu_down_read_trylock()
63 * their sem->read_count, so that it doesn't matter that the writer in __percpu_down_read_trylock()
78 /* Prod writer to re-evaluate readers_active_check() */ in __percpu_down_read_trylock()
79 rcuwait_wake_up(&sem->writer); in __percpu_down_read_trylock()
116 * Specifically, we wake readers until we've woken a single writer, or until a
138 return !reader; /* wake (readers until) 1 writer */ in percpu_rwsem_wake_function()
234 * Try set sem->block; this provides writer-writer exclusion. in percpu_down_write()
[all …]
H A Drwbase_rt.c4 * RT-specific reader/writer semaphores and reader/writer locks
26 * 2) Wake the writer waiting in down_write()/write_lock() #3
29 * locks on RT are not writer fair, but writers, which should be avoided in
33 * It's possible to make the rw primitives writer fair by keeping a list of
34 * active readers. A blocked writer would force all newly incoming readers
41 * The risk of writer starvation is there, but the pathological use cases
80 * Reader1 Reader2 Writer in __rwbase_read_lock()
88 * wake(Writer) in __rwbase_read_lock()
102 * That would put Reader1 behind the writer waiting on in __rwbase_read_lock()
115 * On success the rtmutex is held, so there can't be a writer in __rwbase_read_lock()
[all …]
H A Drwsem.c7 * Writer lock-stealing by Alex Shi <alex.shi@intel.com>
41 * When the rwsem is reader-owned and a spinning writer has timed out,
44 * When a writer acquires a rwsem, it puts its task_struct pointer
59 * is previously owned by a writer and the following conditions are met:
60 * - rwsem is not currently writer owned
84 * Bit 0 - writer locked bit
93 * Bit 0 - writer locked bit
106 * atomic_long_cmpxchg() will be used to obtain writer lock.
113 * For all the above cases, wait_lock will be held. A writer must also
294 * by a writer.
[all …]
/openbmc/openbmc/poky/scripts/pybootchartgui/pybootchartgui/
H A Dparsing.py34 def __init__(self, writer, paths, options): argument
58 parse_paths (writer, self, paths)
83 self.compile(writer)
88 idle = self.crop (writer, options.crop_after)
104 self.proc_tree = ProcessTree(writer, self.kernel, self.ps_stats,
111 self.kernel_tree = ProcessTree(writer, self.kernel, None, 0,
131 def compile(self, writer): argument
177 def crop(self, writer, crop_after): argument
204 writer.info("selected proc '%s' from list (start %d)"
208 writer.warn("no selected crop proc '%s' in list" % crop_after)
[all …]
H A Dsamples.py118 def __init__(self, writer, process_map, sample_count, sample_period, start_time, end_time): argument
124 writer.info ("%d samples, avg. sample length %f" % (self.sample_count, self.sample_period))
125 writer.info ("process list size: %d" % len (self.process_map.values()))
128 def __init__(self, writer, pid, cmd, ppid, start_time): argument
129 self.writer = writer
150 def split(self, writer, pid, cmd, ppid, start_time): argument
151 split = Process (writer, pid, cmd, ppid, start_time)
188 … self.writer.warn("Missing CONFIG_PROC_EVENTS: no parent for pid '%i' ('%s') with ppid '%i'" \
/openbmc/openbmc/meta-openembedded/meta-perl/recipes-perl/libxml/
H A Dlibxml-sax-writer-perl_0.57.bb1 SUMMARY = "XML::SAX::Writer - SAX2 Writer"
3 XML::SAX::Writer helps to serialize SAX2 representations of XML documents to \
11 HOMEPAGE = "https://metacpan.org/dist/XML-SAX-Writer"
15 SRC_URI = "${CPAN_MIRROR}/authors/id/P/PE/PERIGRIN/XML-SAX-Writer-${PV}.tar.gz"
20 S = "${WORKDIR}/XML-SAX-Writer-${PV}"
/openbmc/qemu/python/qemu/qmp/
H A Dutil.py33 async def flush(writer: asyncio.StreamWriter) -> None:
44 asyncio.WriteTransport, writer.transport
51 await writer.drain()
107 def is_closing(writer: asyncio.StreamWriter) -> bool:
111 :param writer: The `asyncio.StreamWriter` object.
112 :return: `True` if the writer is closing, or closed.
115 return writer.is_closing()
118 transport = writer.transport
123 async def wait_closed(writer: asyncio.StreamWriter) -> None:
127 :param writer: The `asyncio.StreamWriter` to wait on.
[all …]
H A Dprotocol.py185 The base implementation starts the reader/writer tasks.
187 actions to be taken prior to starting the reader/writer tasks
238 #: reader/writer) are allowed to wait for the reader/writers to
395 :raise Exception: When the reader or writer terminate unexpectedly.
505 writer: asyncio.StreamWriter) -> None:
515 :param writer: Incoming `asyncio.StreamWriter`
517 peer = writer.get_extra_info('peername', 'Unknown peer')
525 writer.close()
531 self._reader, self._writer = (reader, writer)
655 Starts the readers/writer tasks; subclasses may perform their
[all …]
/openbmc/qemu/include/block/
H A Dgraph-lock.h30 * Currently we have 1 writer only, the Main loop, and many
33 * We distinguish between writer (main loop, under BQL) that modifies the
38 * The writer (main loop) has an "exclusive" access, so it first waits for
43 * access the graph as long the writer is not modifying the graph.
44 * In case it is, they go in a CoQueue and sleep until the writer
48 * AioContext are left intact, since the writer does not care where is the
54 * so that the writer is always aware of all readers.
131 * and if has_writer is set, it means that the writer is modifying
133 * The writer will then wake this coroutine once it is done.
136 * because it signals the writer that there are some
[all …]
/openbmc/qemu/block/
H A Dgraph-lock.c47 /* Queue of readers waiting for the writer to finish */
119 * reader_count == 0: this means writer will read has_reader as 1 in bdrv_graph_wrlock()
120 * reader_count >= 1: we don't know if writer read has_writer == 0 or 1, in bdrv_graph_wrlock()
181 /* make sure writer sees reader_count before we check has_writer */ in bdrv_graph_co_rdlock()
185 * has_writer == 0: this means writer will read reader_count as >= 1 in bdrv_graph_co_rdlock()
186 * has_writer == 1: we don't know if writer read reader_count == 0 in bdrv_graph_co_rdlock()
199 * Then the writer will read reader_count that does not take into in bdrv_graph_co_rdlock()
204 * then writer will read reader_count >= 1. in bdrv_graph_co_rdlock()
215 * Then the writer will set has_writer to 0 and wake up all readers, in bdrv_graph_co_rdlock()
221 * again for has_writer, otherwise we sleep without any writer in bdrv_graph_co_rdlock()
[all …]
/openbmc/linux/include/linux/
H A Dpercpu-rwsem.h15 struct rcuwait writer; member
34 .writer = __RCUWAIT_INITIALIZER(name.writer), \
55 * We are in an RCU-sched read-side critical section, so the writer in percpu_down_read()
58 * the writer won't be checking until we're past the preempt_enable() in percpu_down_read()
59 * and that once the synchronize_rcu() is done, the writer will see in percpu_down_read()
110 * writer. in percpu_up_read()
119 rcuwait_wake_up(&sem->writer); in percpu_up_read()
/openbmc/linux/Documentation/locking/
H A Dseqlock.rst8 Sequence counters are a reader-writer consistency mechanism with
9 lockless readers (read-only retry loops), and no writer starvation. They
30 interrupted writer. If that reader belongs to a real-time scheduling
34 as the writer can invalidate a pointer that the reader is following.
53 requirements of writer serialization and non-preemptibility, use
97 sequence counters associate the lock used for writer serialization at
165 embedded spinlock for writer serialization and non-preemptibility.
195 1. Normal Sequence readers which never block a writer but they must
196 retry if a writer is in progress by detecting change in the sequence
206 2. Locking readers which will wait if a writer or another locking reader
[all …]
/openbmc/openbmc/meta-openembedded/meta-oe/recipes-support/bmap-writer/
H A Dbmap-writer_git.bb2 DESCRIPTION = "bmap-writer is a command-line utility designed to efficiently write disk images \
5 bmap-writer is C++ based does not require Python and focuses solely on writing an image."
6 HOMEPAGE = "https://github.com/embetrix/bmap-writer"
20 FILES:${PN} = "${bindir}/bmap-writer"
/openbmc/linux/kernel/trace/
H A Dtrace_recursion_record.c43 * If there's two writers and this writer comes in second, in ftrace_record_recursion()
45 * writer will try again. It is possible that index will now in ftrace_record_recursion()
46 * be greater than nr_records. This is because the writer in ftrace_record_recursion()
48 * This writer could keep trying again until the other writer in ftrace_record_recursion()
49 * updates nr_records. But if the other writer takes an in ftrace_record_recursion()
54 * writer will simply use the next position to update the in ftrace_record_recursion()
/openbmc/linux/scripts/
H A Djobserver-exec30 # Starting with GNU Make 4.4, named pipes are used for reader and writer.
36 writer = os.open(path, os.O_WRONLY) variable
38 reader, writer = [int(x) for x in fds.split(",", 1)]
55 os.write(writer, jobs)
75 os.write(writer, jobs)
/openbmc/linux/tools/perf/util/
H A Ddata-convert-bt.c14 #include <babeltrace/ctf-writer/writer.h>
15 #include <babeltrace/ctf-writer/clock.h>
16 #include <babeltrace/ctf-writer/stream.h>
17 #include <babeltrace/ctf-writer/event.h>
18 #include <babeltrace/ctf-writer/event-types.h>
19 #include <babeltrace/ctf-writer/event-fields.h>
63 /* writer primitives */
64 struct bt_ctf_writer *writer; member
92 struct ctf_writer writer; member
704 stream = bt_ctf_writer_create_stream(cw->writer, cw->stream_class); in ctf_stream__create()
[all …]
/openbmc/linux/drivers/acpi/acpica/
H A Dutlock.c4 * Module Name: utlock - Reader/Writer lock interfaces
25 * DESCRIPTION: Reader/writer lock creation and deletion interfaces.
62 * DESCRIPTION: Reader interfaces for reader/writer locks. On acquisition,
122 * DESCRIPTION: Writer interfaces for reader/writer locks. Simply acquire or
123 * release the writer mutex associated with the lock. Acquisition
/openbmc/phosphor-pid-control/sensors/
H A Dpluggable.hpp13 * A Sensor that can use any reader or writer you provide.
20 std::unique_ptr<WriteInterface> writer) : in PluggableSensor() argument
22 _writer(std::move(writer)) in PluggableSensor()
/openbmc/linux/arch/arc/include/asm/
H A Dspinlock.h75 * Read-write spinlocks, allowing multiple readers but only one writer.
84 * zero means writer holds the lock exclusively, deny Reader. in arch_read_lock()
140 * deny writer. Otherwise if unlocked grant to writer in arch_write_lock()
290 * Read-write spinlocks, allowing multiple readers but only one writer.
307 * zero means writer holds the lock exclusively, deny Reader. in arch_read_trylock()
332 * deny writer. Otherwise if unlocked grant to writer in arch_write_trylock()

12345678910>>...17