Home
last modified time | relevance | path

Searched full:pool (Results 1 – 25 of 3603) sorted by relevance

12345678910>>...145

/external/skia/tests/
DGrBlockAllocatorTest.cpp18 static int block_count(const GrSBlockAllocator<N>& pool) { in block_count() argument
20 for (const Block* b : pool->blocks()) { in block_count()
28 static Block* get_block(GrSBlockAllocator<N>& pool, int blockIndex) { in get_block() argument
31 for (Block* b: pool->blocks()) { in get_block()
47 static size_t total_size(GrSBlockAllocator<N>& pool) { in total_size() argument
48 return pool->totalSize() - pool->testingOnly_scratchBlockSize(); in total_size()
52 static size_t add_block(GrSBlockAllocator<N>& pool) { in add_block() argument
53 size_t currentSize = total_size(pool); in add_block()
54 GrBlockAllocator::Block* current = pool->currentBlock(); in add_block()
55 while(pool->currentBlock() == current) { in add_block()
[all …]
/external/mesa3d/src/gallium/drivers/r600/
Dcompute_memory_pool.c48 static void compute_memory_shadow(struct compute_memory_pool* pool,
51 static void compute_memory_defrag(struct compute_memory_pool *pool,
55 static int compute_memory_promote_item(struct compute_memory_pool *pool,
59 static void compute_memory_move_item(struct compute_memory_pool *pool,
64 static void compute_memory_transfer(struct compute_memory_pool* pool,
70 * Creates a new pool.
75 struct compute_memory_pool* pool = (struct compute_memory_pool*) in compute_memory_pool_new() local
77 if (!pool) in compute_memory_pool_new()
82 pool->screen = rscreen; in compute_memory_pool_new()
83 pool->item_list = (struct list_head *) in compute_memory_pool_new()
[all …]
/external/tensorflow/tensorflow/core/common_runtime/gpu/
Dpool_allocator_test.cc31 PoolAllocator pool( in TEST() local
37 new NoopRounder, "pool"); in TEST()
39 EXPECT_EQ(nullptr, pool.AllocateRaw(4 /*alignment*/, 0 /*num_bytes*/)); in TEST()
40 pool.DeallocateRaw(nullptr); // Should not crash. in TEST()
41 EXPECT_EQ(0, pool.get_from_pool_count()); in TEST()
42 EXPECT_EQ(0, pool.put_count()); in TEST()
43 EXPECT_EQ(0, pool.allocated_count()); in TEST()
44 EXPECT_EQ(0, pool.evicted_count()); in TEST()
51 PoolAllocator pool( in TEST() local
57 new NoopRounder, "pool"); in TEST()
[all …]
/external/okhttp/okhttp-tests/src/test/java/com/squareup/okhttp/
DConnectionPoolTest.java48 ConnectionPool pool = new ConnectionPool(Integer.MAX_VALUE, 100L, TimeUnit.NANOSECONDS); in connectionsEvictedWhenIdleLongEnough() local
49 pool.setCleanupRunnableForTest(emptyRunnable); in connectionsEvictedWhenIdleLongEnough()
51 RealConnection c1 = newConnection(pool, routeA1, 50L); in connectionsEvictedWhenIdleLongEnough()
53 // Running at time 50, the pool returns that nothing can be evicted until time 150. in connectionsEvictedWhenIdleLongEnough()
54 assertEquals(100L, pool.cleanup(50L)); in connectionsEvictedWhenIdleLongEnough()
55 assertEquals(1, pool.getConnectionCount()); in connectionsEvictedWhenIdleLongEnough()
58 // Running at time 60, the pool returns that nothing can be evicted until time 150. in connectionsEvictedWhenIdleLongEnough()
59 assertEquals(90L, pool.cleanup(60L)); in connectionsEvictedWhenIdleLongEnough()
60 assertEquals(1, pool.getConnectionCount()); in connectionsEvictedWhenIdleLongEnough()
63 // Running at time 149, the pool returns that nothing can be evicted until time 150. in connectionsEvictedWhenIdleLongEnough()
[all …]
/external/mesa3d/src/gallium/frontends/nine/
Dthreadpool.c44 struct threadpool *pool = data; in threadpool_worker() local
46 pthread_mutex_lock(&pool->m); in threadpool_worker()
48 while (!pool->shutdown) { in threadpool_worker()
52 while (!pool->workqueue && !pool->shutdown) in threadpool_worker()
53 pthread_cond_wait(&pool->new_work, &pool->m); in threadpool_worker()
55 if (pool->shutdown) in threadpool_worker()
62 task = pool->workqueue; in threadpool_worker()
63 pool->workqueue = task->next; in threadpool_worker()
66 pthread_mutex_unlock(&pool->m); in threadpool_worker()
68 pthread_mutex_lock(&pool->m); in threadpool_worker()
[all …]
/external/wayland/src/
Dwayland-shm.c75 struct wl_shm_pool *pool; member
85 shm_pool_finish_resize(struct wl_shm_pool *pool) in shm_pool_finish_resize() argument
89 if (pool->size == pool->new_size) in shm_pool_finish_resize()
92 data = mremap(pool->data, pool->size, pool->new_size, MREMAP_MAYMOVE); in shm_pool_finish_resize()
94 wl_resource_post_error(pool->resource, in shm_pool_finish_resize()
100 pool->data = data; in shm_pool_finish_resize()
101 pool->size = pool->new_size; in shm_pool_finish_resize()
105 shm_pool_unref(struct wl_shm_pool *pool, bool external) in shm_pool_unref() argument
108 pool->external_refcount--; in shm_pool_unref()
109 if (pool->external_refcount == 0) in shm_pool_unref()
[all …]
/external/deqp/framework/delibs/depool/
DdeMemPool.c2 * drawElements Memory Pool Library
21 * \brief Memory pool management.
48 * Represent a page of memory allocate by a memory pool.
69 * \brief Memory pool.
71 * A pool of memory from which individual memory allocations can be made.
73 * but rather all of the memory allocated from a pool is freed when the pool
76 * The pools can be arranged into a hierarchy. If a pool with children is
78 * the pool itself.
82 * creating the root pool with the deMemPool_createFailingRoot() function.
92 deMemPool* firstChild; /*!< Pointer to first child pool in linked list. */
[all …]
/external/libiio/src/iiod/
Dthread-pool.c18 #include "thread-pool.h"
46 struct thread_pool *pool; member
51 static void thread_pool_thread_started(struct thread_pool *pool) in thread_pool_thread_started() argument
53 pthread_mutex_lock(&pool->thread_count_lock); in thread_pool_thread_started()
54 pool->thread_count++; in thread_pool_thread_started()
55 pthread_mutex_unlock(&pool->thread_count_lock); in thread_pool_thread_started()
58 static void thread_pool_thread_stopped(struct thread_pool *pool) in thread_pool_thread_stopped() argument
60 pthread_mutex_lock(&pool->thread_count_lock); in thread_pool_thread_stopped()
61 pool->thread_count--; in thread_pool_thread_stopped()
62 pthread_cond_signal(&pool->thread_count_cond); in thread_pool_thread_stopped()
[all …]
/external/autotest/site_utils/
Dbalance_pools.py6 """Adjust pool balances to cover DUT shortfalls.
8 This command takes all broken DUTs in a specific pool for specific
9 models and swaps them with working DUTs taken from a selected pool
12 pool sizes, or to create or remove pools.
14 usage: balance_pool.py [ options ] POOL MODEL [ MODEL ... ]
17 POOL Name of the pool to balance
23 Set the number of DUTs in the pool to the specified
26 Add the specified number of DUTs to the pool for every
29 Remove the specified number of DUTs from the pool for
31 -s POOL, --spare POOL
[all …]
/external/mesa3d/src/util/
Dslab.c48 * - a pointer to the child pool to which this element belongs, or
62 /* Next page in the same child pool. */
83 * pool has been destroyed). Mark the element as freed and free the whole page
99 * Create a parent pool for the allocation of same-sized objects.
122 * Create a child pool linked to the given parent.
124 void slab_create_child(struct slab_child_pool *pool, in slab_create_child() argument
127 pool->parent = parent; in slab_create_child()
128 pool->pages = NULL; in slab_create_child()
129 pool->free = NULL; in slab_create_child()
130 pool->migrated = NULL; in slab_create_child()
[all …]
/external/iproute2/man/man8/
Ddevlink-sb.833 .B pool
37 .BI "devlink sb pool set " DEV "
41 .BI pool " POOL_INDEX "
53 .B pool
57 .BI "devlink sb port pool set " DEV/PORT_INDEX "
61 .BI pool " POOL_INDEX "
85 .BI pool " POOL_INDEX "
124 .SS devlink sb pool show - display available pools and their attributes
131 .SS devlink sb pool set - set attributes of pool
135 - specifies the devlink device to set pool.
[all …]
/external/mesa3d/src/gallium/drivers/llvmpipe/
Dlp_cs_tpool.c27 * compute shader thread pool.
38 struct lp_cs_tpool *pool = data; in lp_cs_tpool_worker() local
42 mtx_lock(&pool->m); in lp_cs_tpool_worker()
44 while (!pool->shutdown) { in lp_cs_tpool_worker()
47 while (list_is_empty(&pool->workqueue) && !pool->shutdown) in lp_cs_tpool_worker()
48 cnd_wait(&pool->new_work, &pool->m); in lp_cs_tpool_worker()
50 if (pool->shutdown) in lp_cs_tpool_worker()
53 task = list_first_entry(&pool->workqueue, struct lp_cs_tpool_task, in lp_cs_tpool_worker()
60 mtx_unlock(&pool->m); in lp_cs_tpool_worker()
62 mtx_lock(&pool->m); in lp_cs_tpool_worker()
[all …]
/external/skqp/src/compute/skc/platforms/cl_12/
Dcq_pool_cl.c34 // The command queue pool could easily be replaced with simply an LRU
35 // or even round-robin reuse pool. Even a small number of aliased
48 struct skc_cq_pool * const pool) in skc_runtime_cl_12_create_cq() argument
61 pool->cq_props, in skc_runtime_cl_12_create_cq()
102 struct skc_cq_pool * const pool, in skc_cq_pool_create() argument
106 pool->size = size + 1; // an empty spot in skc_cq_pool_create()
107 pool->reads = 0; in skc_cq_pool_create()
108 pool->writes = size; in skc_cq_pool_create()
110 pool->cq_props = cq_props; in skc_cq_pool_create()
111 pool->cq = skc_runtime_host_perm_alloc(runtime,SKC_MEM_FLAGS_READ_WRITE, in skc_cq_pool_create()
[all …]
/external/mesa3d/src/freedreno/vulkan/
Dtu_query.c100 * pool. */
101 #define query_iova(type, pool, query, field) \ argument
102 pool->bo.iova + pool->stride * (query) + offsetof(type, field)
104 #define occlusion_query_iova(pool, query, field) \ argument
105 query_iova(struct occlusion_query_slot, pool, query, field)
107 #define pipeline_stat_query_iova(pool, query, field) \ argument
108 pool->bo.iova + pool->stride * query + \
111 #define primitive_query_iova(pool, query, field, i) \ argument
112 query_iova(struct primitive_query_slot, pool, query, field) + \
115 #define query_available_iova(pool, query) \ argument
[all …]
/external/mesa3d/src/intel/vulkan/
Danv_allocator.c84 * At the next level we can use various sub-allocators. The state pool is a
85 * pool of smaller, fixed size objects, which operates much like the block
86 * pool. It uses a free list for freeing objects, but when it runs out of
87 * space it just allocates a new block from the block pool. This allocator is
189 /* Assert that we only ever grow the pool */ in anv_state_table_expand_range()
202 /* Just leak the old map until we destroy the pool. We can't munmap it in anv_state_table_expand_range()
233 /* The block pool is always initialized to a nonzero size and this function in anv_state_table_grow()
294 /* We allocated the first block outside the pool so we have to grow in anv_state_table_add()
295 * the pool. pool_state->next acts a mutex: threads who try to in anv_state_table_add()
361 anv_block_pool_expand_range(struct anv_block_pool *pool,
[all …]
/external/protobuf/python/google/protobuf/internal/
Ddescriptor_pool_test.py70 file_desc1 = self.pool.FindFileByName(name1)
77 file_desc2 = self.pool.FindFileByName(name2)
85 self.pool.FindFileByName('Does not exist')
88 file_desc1 = self.pool.FindFileContainingSymbol(
96 file_desc2 = self.pool.FindFileContainingSymbol(
105 file_desc3 = self.pool.FindFileContainingSymbol(
112 file_desc4 = self.pool.FindFileContainingSymbol(
118 file_desc5 = self.pool.FindFileContainingSymbol(
123 # Tests the generated pool.
132 file_desc6 = self.pool.FindFileContainingSymbol(
[all …]
/external/python/cpython2/Doc/includes/
Dmp_pool.py2 # A test of `multiprocessing.Pool` class
52 # Create pool
56 print 'Creating pool with %d processes\n' % PROCESSES
57 pool = multiprocessing.Pool(PROCESSES)
58 print 'pool = %s' % pool
68 results = [pool.apply_async(calculate, t) for t in TASKS]
69 imap_it = pool.imap(calculatestar, TASKS)
70 imap_unordered_it = pool.imap_unordered(calculatestar, TASKS)
72 print 'Ordered results using pool.apply_async():'
77 print 'Ordered results using pool.imap():'
[all …]
/external/boringssl/src/crypto/pool/
Dpool.c15 #include <openssl/pool.h>
42 CRYPTO_BUFFER_POOL *pool = OPENSSL_malloc(sizeof(CRYPTO_BUFFER_POOL)); in CRYPTO_BUFFER_POOL_new() local
43 if (pool == NULL) { in CRYPTO_BUFFER_POOL_new()
47 OPENSSL_memset(pool, 0, sizeof(CRYPTO_BUFFER_POOL)); in CRYPTO_BUFFER_POOL_new()
48 pool->bufs = lh_CRYPTO_BUFFER_new(CRYPTO_BUFFER_hash, CRYPTO_BUFFER_cmp); in CRYPTO_BUFFER_POOL_new()
49 if (pool->bufs == NULL) { in CRYPTO_BUFFER_POOL_new()
50 OPENSSL_free(pool); in CRYPTO_BUFFER_POOL_new()
54 CRYPTO_MUTEX_init(&pool->lock); in CRYPTO_BUFFER_POOL_new()
56 return pool; in CRYPTO_BUFFER_POOL_new()
59 void CRYPTO_BUFFER_POOL_free(CRYPTO_BUFFER_POOL *pool) { in CRYPTO_BUFFER_POOL_free() argument
[all …]
/external/rust/crates/quiche/deps/boringssl/src/crypto/pool/
Dpool.c15 #include <openssl/pool.h>
42 CRYPTO_BUFFER_POOL *pool = OPENSSL_malloc(sizeof(CRYPTO_BUFFER_POOL)); in CRYPTO_BUFFER_POOL_new() local
43 if (pool == NULL) { in CRYPTO_BUFFER_POOL_new()
47 OPENSSL_memset(pool, 0, sizeof(CRYPTO_BUFFER_POOL)); in CRYPTO_BUFFER_POOL_new()
48 pool->bufs = lh_CRYPTO_BUFFER_new(CRYPTO_BUFFER_hash, CRYPTO_BUFFER_cmp); in CRYPTO_BUFFER_POOL_new()
49 if (pool->bufs == NULL) { in CRYPTO_BUFFER_POOL_new()
50 OPENSSL_free(pool); in CRYPTO_BUFFER_POOL_new()
54 CRYPTO_MUTEX_init(&pool->lock); in CRYPTO_BUFFER_POOL_new()
56 return pool; in CRYPTO_BUFFER_POOL_new()
59 void CRYPTO_BUFFER_POOL_free(CRYPTO_BUFFER_POOL *pool) { in CRYPTO_BUFFER_POOL_free() argument
[all …]
/external/mesa3d/src/broadcom/vulkan/
Dv3dv_query.c41 struct v3dv_query_pool *pool = in v3dv_CreateQueryPool() local
42 vk_alloc2(&device->alloc, pAllocator, sizeof(*pool), 8, in v3dv_CreateQueryPool()
44 if (pool == NULL) in v3dv_CreateQueryPool()
47 pool->query_type = pCreateInfo->queryType; in v3dv_CreateQueryPool()
48 pool->query_count = pCreateInfo->queryCount; in v3dv_CreateQueryPool()
52 const uint32_t pool_bytes = sizeof(struct v3dv_query) * pool->query_count; in v3dv_CreateQueryPool()
53 pool->queries = vk_alloc2(&device->alloc, pAllocator, pool_bytes, 8, in v3dv_CreateQueryPool()
55 if (pool->queries == NULL) { in v3dv_CreateQueryPool()
61 for (i = 0; i < pool->query_count; i++) { in v3dv_CreateQueryPool()
62 pool->queries[i].maybe_available = false; in v3dv_CreateQueryPool()
[all …]
/external/proguard/src/proguard/classfile/editor/
DConstantPoolEditor.java27 * This class can add constant pool entries to a given class.
49 * Finds or creates a IntegerConstant constant pool entry with the given
51 * @return the constant pool index of the Utf8Constant.
79 * Finds or creates a LongConstant constant pool entry with the given value.
80 * @return the constant pool index of the LongConstant.
108 * Finds or creates a FloatConstant constant pool entry with the given
110 * @return the constant pool index of the FloatConstant.
138 * Finds or creates a DoubleConstant constant pool entry with the given
140 * @return the constant pool index of the DoubleConstant.
168 * Finds or creates a StringConstant constant pool entry with the given
[all …]
/external/skia/src/sksl/
DSkSLPool.h21 * All allocated memory must be released back to the pool before it can be destroyed or recycled.
24 class Pool {
26 ~Pool();
28 // Creates a pool to store objects during program creation. Call attachToThread() to start using
29 // the pool for its allocations. When your program is complete, call pool->detachFromThread() to
30 // take ownership of the pool and its allocations. Before freeing any of the program's
31 // allocations, make sure to reattach the pool by calling pool->attachToThread() again.
32 static std::unique_ptr<Pool> Create();
34 // Attaches a pool to the current thread.
35 // It is an error to call this while a pool is already attached.
[all …]
DSkSLPool.cpp54 Pool::~Pool() { in ~Pool()
56 SkDEBUGFAIL("SkSL pool is being destroyed while it is still attached to the thread"); in ~Pool()
63 VLOG("DELETE Pool:0x%016llX\n", (uint64_t)fMemPool.get()); in ~Pool()
66 std::unique_ptr<Pool> Pool::Create() { in Create()
67 auto pool = std::unique_ptr<Pool>(new Pool); in Create() local
68 pool->fMemPool = MemoryPool::Make(/*preallocSize=*/65536, /*minAllocSize=*/32768); in Create()
69 VLOG("CREATE Pool:0x%016llX\n", (uint64_t)pool->fMemPool.get()); in Create()
70 return pool; in Create()
73 bool Pool::IsAttached() { in IsAttached()
77 void Pool::attachToThread() { in attachToThread()
[all …]
/external/rust/crates/regex/src/
Dpool.rs1 // This module provides a relatively simple thread-safe pool of reusable
4 // costly, in the case where a pool is accessed by the first thread that tried
14 // using the 'thread_local' crate to implement the pool below.
16 // (2) represents a naive pool implemented completely via Mutex<Vec<T>>. There
20 // fast because a Box<T> is much smaller than the T we use with a Pool in this
38 // have used a regex, where as the pool below scales to the number of threads
40 // since we own the pool data structure below, we can add contraction if a
46 // threads. In contrast, the pool below scales with the total number of threads
47 // *simultaneously* using the pool. The hope is that this uses less memory
72 // thread ID might result in more than one thread "owning" a pool,
[all …]
/external/rust/crates/futures-executor/tests/
Dlocal_pool.rs32 let mut pool = LocalPool::new(); in run_until_single_future() localVariable
36 pool.run_until(fut); in run_until_single_future()
44 let mut pool = LocalPool::new(); in run_until_ignores_spawned() localVariable
45 let spawn = pool.spawner(); in run_until_ignores_spawned()
47 pool.run_until(lazy(|_| ())); in run_until_ignores_spawned()
53 let mut pool = LocalPool::new(); in run_until_executes_spawned() localVariable
54 let spawn = pool.spawner(); in run_until_executes_spawned()
58 pool.run_until(rx).unwrap(); in run_until_executes_spawned()
63 let mut pool = LocalPool::new(); in run_returns_if_empty() localVariable
64 pool.run(); in run_returns_if_empty()
[all …]

12345678910>>...145