/commonlibrary/rust/ylong_runtime/ylong_runtime/tests/ |
H A D | sync.rs | 14 #![cfg(feature = "sync")] 18 use std::sync::atomic::AtomicUsize; 19 use std::sync::atomic::Ordering::{Acquire, Release}; 20 use std::sync::{Arc, Mutex}; 26 use ylong_runtime::sync::{Mutex as YlongMutex, RwLock, Waiter}; 227 let producer_lock = Arc::new(std::sync::RwLock::new(1)); in sdv_rwlock_multi_threads()
|
H A D | join_set.rs | 16 use std::sync::atomic::AtomicUsize; 17 use std::sync::atomic::Ordering::Relaxed; 18 use std::sync::Arc;
|
H A D | yield.rs | 14 use std::sync::atomic::Ordering::{Acquire, Release}; 15 use std::sync::atomic::{AtomicUsize, Ordering}; 16 use std::sync::Arc;
|
H A D | mutex.rs | 22 #![cfg(all(feature = "sync", feature = "time"))] 24 use std::sync::Arc; 28 use ylong_runtime::sync::Mutex;
|
/commonlibrary/memory_utils/libdmabufheap/src/ |
H A D | dmabuf_alloc.c | 132 struct dma_buf_sync sync = {0}; in DmabufHeapBufferSyncStart() local 133 sync.flags = DMA_BUF_SYNC_START | syncType; in DmabufHeapBufferSyncStart() 134 return ioctl(fd, DMA_BUF_IOCTL_SYNC, &sync); in DmabufHeapBufferSyncStart() 144 struct dma_buf_sync sync = {0}; in DmabufHeapBufferSyncEnd() local 145 sync.flags = DMA_BUF_SYNC_END | syncType; in DmabufHeapBufferSyncEnd() 146 return ioctl(fd, DMA_BUF_IOCTL_SYNC, &sync); in DmabufHeapBufferSyncEnd()
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/process/sys/unix/ |
H A D | zombie_manager.rs | 16 use std::sync::{Mutex, MutexGuard, Once}; 20 use crate::sync::watch; 21 use crate::sync::watch::Receiver;
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/sync/ |
H A D | watch.rs | 18 use std::sync::atomic::AtomicUsize; 19 use std::sync::atomic::Ordering::{Acquire, Release}; 20 use std::sync::{Arc, RwLock, RwLockReadGuard}; 25 use crate::sync::error::{RecvError, SendError}; 26 use crate::sync::wake_list::WakerList; 41 /// use ylong_runtime::sync::watch; 71 /// use ylong_runtime::sync::watch; 97 /// use ylong_runtime::sync::watch; 130 /// use ylong_runtime::sync::watch; 155 /// use ylong_runtime::sync [all...] |
H A D | oneshot.rs | 27 //! use ylong_runtime::sync::oneshot; 46 use std::sync::atomic::AtomicUsize; 47 use std::sync::atomic::Ordering::{AcqRel, Acquire, Release, SeqCst}; 48 use std::sync::Arc; 69 /// use ylong_runtime::sync::oneshot; 100 /// use ylong_runtime::sync::oneshot; 122 /// use ylong_runtime::sync::oneshot; 150 /// use ylong_runtime::sync::oneshot; 199 /// use ylong_runtime::sync::oneshot; 234 /// use ylong_runtime::sync [all...] |
H A D | semaphore_inner.rs | 18 use std::sync::atomic::AtomicUsize; 19 use std::sync::atomic::Ordering::{AcqRel, Acquire, Release}; 23 use crate::sync::wake_list::WakerList;
|
H A D | mutex.rs | 22 use crate::sync::semaphore_inner::SemaphoreInner; 24 /// An async version of [`std::sync::Mutex`] 26 /// Often it's considered as normal to use [`std::sync::Mutex`] on an 30 /// different threads, [`std::sync::Mutex`] will probably gain you better 34 /// Arc, just like the use of [`std::sync::Mutex`]. 63 /// use ylong_runtime::sync::mutex::Mutex; 85 /// use std::sync::Arc; 87 /// use ylong_runtime::sync::mutex::Mutex; 111 /// use std::sync::Arc; 113 /// use ylong_runtime::sync [all...] |
H A D | atomic_waker.rs | 16 use std::sync::atomic::AtomicU8; 17 use std::sync::atomic::Ordering::{AcqRel, Acquire, Release};
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/signal/unix/ |
H A D | registry.rs | 18 use std::sync::atomic::AtomicBool; 19 use std::sync::atomic::Ordering::{Acquire, Release, SeqCst}; 20 use std::sync::Once; 26 use crate::sync::watch::{channel, Receiver, Sender};
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/sync/mpsc/unbounded/ |
H A D | mod.rs | 21 use crate::sync::error::{RecvError, SendError, TryRecvError}; 22 use crate::sync::mpsc::unbounded::queue::Queue; 23 use crate::sync::mpsc::{channel, Container, Rx, Tx}; 28 use crate::sync::error::RecvTimeoutError; 37 /// use ylong_runtime::sync::mpsc::unbounded::unbounded_channel; 68 /// use ylong_runtime::sync::mpsc::unbounded::unbounded_channel; 89 /// use ylong_runtime::sync::mpsc::unbounded::unbounded_channel; 117 /// use ylong_runtime::sync::mpsc::unbounded::unbounded_channel; 135 /// use ylong_runtime::sync::mpsc::unbounded::unbounded_channel; 150 /// use ylong_runtime::sync [all...] |
H A D | queue.rs | 18 use std::sync::atomic::Ordering::{AcqRel, Acquire, Release}; 19 use std::sync::atomic::{AtomicBool, AtomicPtr, AtomicUsize}; 23 use crate::sync::atomic_waker::AtomicWaker; 24 use crate::sync::error::{RecvError, SendError, TryRecvError}; 25 use crate::sync::mpsc::Container;
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/sync/mpsc/bounded/ |
H A D | array.rs | 18 use std::sync::atomic::AtomicUsize; 19 use std::sync::atomic::Ordering::{AcqRel, Acquire, Release}; 23 use crate::sync::atomic_waker::AtomicWaker; 24 use crate::sync::error::{RecvError, SendError, TryRecvError, TrySendError}; 25 use crate::sync::mpsc::Container; 26 use crate::sync::wake_list::WakerList;
|
H A D | mod.rs | 21 use crate::sync::error::{RecvError, SendError, TryRecvError, TrySendError}; 22 use crate::sync::mpsc::bounded::array::Array; 23 use crate::sync::mpsc::{channel, Container, Rx, Tx}; 25 use crate::sync::error::{RecvTimeoutError, SendTimeoutError}; 26 use crate::sync::mpsc::bounded::array::SendPosition; 38 /// use ylong_runtime::sync::mpsc::bounded::bounded_channel; 73 /// use ylong_runtime::sync::mpsc::bounded::bounded_channel; 104 /// use ylong_runtime::sync::mpsc::bounded::bounded_channel; 141 /// use ylong_runtime::sync::error::TryRecvError; 142 /// use ylong_runtime::sync [all...] |
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/executor/ |
H A D | current_thread.rs | 19 use std::sync::atomic::AtomicU64; 20 use std::sync::atomic::AtomicUsize; 21 use std::sync::atomic::Ordering::{AcqRel, Acquire}; 22 use std::sync::{Arc, Condvar, Mutex}; 308 #[cfg(feature = "sync")] 318 use crate::sync::Waiter; 319 use std::sync::atomic::AtomicUsize; 320 use std::sync::atomic::Ordering::{Acquire, Release}; 321 use std::sync::{Condvar, Mutex}; 322 use std::sync [all...] |
/commonlibrary/rust/ylong_runtime/ylong_runtime/benches/bin/ |
H A D | ylong_sync_mutex_perf.rs | 16 use std::sync::Arc; 19 use ylong_runtime::sync::Mutex;
|
H A D | ylong_sync_rwlock_perf.rs | 16 use std::sync::Arc; 19 use ylong_runtime::sync::rwlock::RwLock;
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/signal/windows/ |
H A D | registry.rs | 15 use std::sync::Once; 17 use crate::sync::watch::{channel, Receiver, Sender};
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/examples/ |
H A D | ylong_runtime_signal.rs | 14 use std::sync::atomic::AtomicUsize; 15 use std::sync::atomic::Ordering::{Acquire, Release}; 16 use std::sync::Arc;
|
/commonlibrary/rust/ylong_http/ylong_http_client/tests/ |
H A D | sdv_async_http2.rs | 22 use std::sync::Arc; 25 use tokio::sync::mpsc::{Receiver, Sender}; 96 use tokio::sync::mpsc::channel; 152 let (tx, rx) = std::sync::mpsc::channel(); in sdv_async_h2_client_send_request() 232 let (tx, rx) = std::sync::mpsc::channel(); in sdv_async_h2_client_send_request_concurrently()
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/net/ |
H A D | driver.rs | 17 use std::sync::atomic::AtomicU64; 18 use std::sync::{Arc, Mutex}; 111 .load(std::sync::atomic::Ordering::Acquire) 119 .load(std::sync::atomic::Ordering::Acquire) 280 .fetch_add(events.len() as u64, std::sync::atomic::Ordering::AcqRel); 297 static ONCE: std::sync::Once = std::sync::Once::new(); in initialize() 394 .fetch_add(1, std::sync::atomic::Ordering::AcqRel);
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/benches/ |
H A D | ylong_tokio_mutex.rs | 95 use std::sync::Arc; 98 use tokio::sync::Mutex; 99 use ylong_runtime::sync::Mutex as YlongMutex;
|
/commonlibrary/rust/ylong_runtime/ylong_runtime/src/sync/mpsc/ |
H A D | mod.rs | 31 use std::sync::atomic::AtomicUsize; 32 use std::sync::atomic::Ordering::{AcqRel, Relaxed}; 33 use std::sync::Arc;
|