Home
last modified time | relevance | path

Searched refs:pool (Results 1 – 25 of 1963) sorted by relevance

12345678910>>...79

/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/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/libiio/src/iiod/
Dthread-pool.c46 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()
63 pthread_mutex_unlock(&pool->thread_count_lock); in thread_pool_thread_stopped()
[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,
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()
85 pool->unallocated_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
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
59 EXPECT_EQ(0, pool.get_from_pool_count()); in TEST()
60 EXPECT_EQ(0, pool.put_count()); in TEST()
[all …]
/external/deqp/framework/delibs/depool/
DdeMemPool.c171 deMemPool* pool; in createPoolInternal() local
189 pool = (deMemPool*)(initialPage + 1); in createPoolInternal()
192 memset(pool, 0, sizeof(deMemPool)); in createPoolInternal()
193 pool->currentPage = initialPage; in createPoolInternal()
196 pool->parent = parent; in createPoolInternal()
200 if (parent->firstChild) parent->firstChild->prevPool = pool; in createPoolInternal()
201 pool->nextPool = parent->firstChild; in createPoolInternal()
202 parent->firstChild = pool; in createPoolInternal()
206 pool->util = parent ? parent->util : DE_NULL; in createPoolInternal()
209 pool->allowFailing = parent ? parent->allowFailing : DE_FALSE; in createPoolInternal()
[all …]
/external/mesa3d/src/gallium/drivers/llvmpipe/
Dlp_cs_tpool.c38 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()
67 mtx_unlock(&pool->m); in lp_cs_tpool_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/mesa3d/src/util/
Dslab.c124 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()
139 void slab_destroy_child(struct slab_child_pool *pool) in slab_destroy_child() argument
141 if (!pool->parent) in slab_destroy_child()
144 mtx_lock(&pool->parent->mutex); in slab_destroy_child()
146 while (pool->pages) { in slab_destroy_child()
147 struct slab_page_header *page = pool->pages; in slab_destroy_child()
[all …]
/external/skqp/src/compute/skc/platforms/cl_12/
Dcq_pool_cl.c48 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()
112 pool->size * sizeof(*pool->cq)); in skc_cq_pool_create()
114 pool->cq[ii] = skc_runtime_cl_12_create_cq(runtime,pool); in skc_cq_pool_create()
[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()
54 assertEquals(100L, pool.cleanup(50L)); in connectionsEvictedWhenIdleLongEnough()
55 assertEquals(1, pool.getConnectionCount()); in connectionsEvictedWhenIdleLongEnough()
59 assertEquals(90L, pool.cleanup(60L)); in connectionsEvictedWhenIdleLongEnough()
60 assertEquals(1, pool.getConnectionCount()); in connectionsEvictedWhenIdleLongEnough()
64 assertEquals(1L, pool.cleanup(149L)); in connectionsEvictedWhenIdleLongEnough()
65 assertEquals(1, pool.getConnectionCount()); in connectionsEvictedWhenIdleLongEnough()
69 assertEquals(0, pool.cleanup(150L)); in connectionsEvictedWhenIdleLongEnough()
[all …]
/external/mesa3d/src/gallium/drivers/r300/compiler/
Dmemory_pool.c38 void memory_pool_init(struct memory_pool * pool) in memory_pool_init() argument
40 memset(pool, 0, sizeof(struct memory_pool)); in memory_pool_init()
44 void memory_pool_destroy(struct memory_pool * pool) in memory_pool_destroy() argument
46 while(pool->blocks) { in memory_pool_destroy()
47 struct memory_block * block = pool->blocks; in memory_pool_destroy()
48 pool->blocks = block->next; in memory_pool_destroy()
53 static void refill_pool(struct memory_pool * pool) in refill_pool() argument
55 unsigned int blocksize = pool->total_allocated; in refill_pool()
62 newblock->next = pool->blocks; in refill_pool()
63 pool->blocks = newblock; in refill_pool()
[all …]
/external/mesa3d/src/freedreno/vulkan/
Dtu_query.c101 #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
116 query_iova(struct query_slot, pool, query, available)
[all …]
/external/mesa3d/src/intel/vulkan/
Danv_allocator.c361 anv_block_pool_expand_range(struct anv_block_pool *pool,
365 anv_block_pool_init(struct anv_block_pool *pool, in anv_block_pool_init() argument
372 pool->device = device; in anv_block_pool_init()
373 pool->use_softpin = device->physical->use_softpin; in anv_block_pool_init()
374 pool->nbos = 0; in anv_block_pool_init()
375 pool->size = 0; in anv_block_pool_init()
376 pool->center_bo_offset = 0; in anv_block_pool_init()
377 pool->start_address = gen_canonical_address(start_address); in anv_block_pool_init()
378 pool->map = NULL; in anv_block_pool_init()
380 if (pool->use_softpin) { in anv_block_pool_init()
[all …]
DgenX_query.c53 anv_query_address(struct anv_query_pool *pool, uint32_t query) in anv_query_address() argument
56 .bo = pool->bo, in anv_query_address()
57 .offset = query * pool->stride, in anv_query_address()
70 struct anv_query_pool *pool; in genX() local
91 anv_multialloc_add(&ma, &pool, 1); in genX()
143 vk_object_base_init(&device->vk, &pool->base, VK_OBJECT_TYPE_QUERY_POOL); in genX()
144 pool->type = pCreateInfo->queryType; in genX()
145 pool->pipeline_statistics = pipeline_statistics; in genX()
146 pool->stride = uint64s_per_slot * sizeof(uint64_t); in genX()
147 pool->slots = pCreateInfo->queryCount; in genX()
[all …]
/external/rust/crates/quiche/deps/boringssl/src/crypto/pool/
Dpool.c42 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
60 if (pool == NULL) { in CRYPTO_BUFFER_POOL_free()
[all …]
/external/boringssl/src/crypto/pool/
Dpool.c42 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
60 if (pool == NULL) { in CRYPTO_BUFFER_POOL_free()
[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/mesa3d/src/gallium/drivers/iris/
Diris_border_color.c66 iris_reset_border_color_pool(struct iris_border_color_pool *pool, in iris_reset_border_color_pool() argument
69 _mesa_hash_table_clear(pool->ht, NULL); in iris_reset_border_color_pool()
71 iris_bo_unreference(pool->bo); in iris_reset_border_color_pool()
73 pool->bo = iris_bo_alloc(bufmgr, "border colors", in iris_reset_border_color_pool()
76 pool->map = iris_bo_map(NULL, pool->bo, MAP_WRITE); in iris_reset_border_color_pool()
79 pool->insert_point = BC_ALIGNMENT; in iris_reset_border_color_pool()
88 struct iris_border_color_pool *pool = &ice->state.border_color_pool; in iris_init_border_color_pool() local
90 pool->bo = NULL; in iris_init_border_color_pool()
91 pool->ht = _mesa_hash_table_create(ice, color_hash, color_equals); in iris_init_border_color_pool()
93 iris_reset_border_color_pool(pool, bufmgr); in iris_init_border_color_pool()
[all …]
/external/mesa3d/src/panfrost/lib/
Dpan_pool.c34 panfrost_pool_alloc_backing(struct pan_pool *pool, size_t bo_sz) in panfrost_pool_alloc_backing() argument
42 struct panfrost_bo *bo = panfrost_bo_create(pool->dev, bo_sz, in panfrost_pool_alloc_backing()
43 pool->create_flags); in panfrost_pool_alloc_backing()
45 util_dynarray_append(&pool->bos, struct panfrost_bo *, bo); in panfrost_pool_alloc_backing()
46 pool->transient_bo = bo; in panfrost_pool_alloc_backing()
47 pool->transient_offset = 0; in panfrost_pool_alloc_backing()
53 panfrost_pool_init(struct pan_pool *pool, void *memctx, in panfrost_pool_init() argument
57 memset(pool, 0, sizeof(*pool)); in panfrost_pool_init()
58 pool->dev = dev; in panfrost_pool_init()
59 pool->create_flags = create_flags; in panfrost_pool_init()
[all …]
/external/volley/src/test/java/com/android/volley/toolbox/
DByteArrayPoolTest.java28 ByteArrayPool pool = new ByteArrayPool(32); in reusesBuffer() local
30 byte[] buf1 = pool.getBuf(16); in reusesBuffer()
31 byte[] buf2 = pool.getBuf(16); in reusesBuffer()
33 pool.returnBuf(buf1); in reusesBuffer()
34 pool.returnBuf(buf2); in reusesBuffer()
36 byte[] buf3 = pool.getBuf(16); in reusesBuffer()
37 byte[] buf4 = pool.getBuf(16); in reusesBuffer()
45 ByteArrayPool pool = new ByteArrayPool(32); in obeysSizeLimit() local
47 byte[] buf1 = pool.getBuf(16); in obeysSizeLimit()
48 byte[] buf2 = pool.getBuf(16); in obeysSizeLimit()
[all …]
DPoolingByteArrayOutputStreamTest.java28 ByteArrayPool pool = new ByteArrayPool(32768); in pooledOneBuffer() local
29 writeOneBuffer(pool); in pooledOneBuffer()
30 writeOneBuffer(pool); in pooledOneBuffer()
31 writeOneBuffer(pool); in pooledOneBuffer()
36 ByteArrayPool pool = new ByteArrayPool(32768); in pooledIndividualWrites() local
37 writeBytesIndividually(pool); in pooledIndividualWrites()
38 writeBytesIndividually(pool); in pooledIndividualWrites()
39 writeBytesIndividually(pool); in pooledIndividualWrites()
44 ByteArrayPool pool = new ByteArrayPool(0); in unpooled() local
45 writeOneBuffer(pool); in unpooled()
[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 …]
/external/python/cpython2/Doc/includes/
Dmp_pool.py57 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)
88 for x in pool.map(calculatestar, TASKS):
105 B = pool.map(pow3, xrange(N))
110 C = list(pool.imap(pow3, xrange(N), chunksize=N//8))
127 B = pool.map(noop, L)
132 C = list(pool.imap(noop, L, chunksize=len(L)//8))
[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(
132 file_desc6 = self.pool.FindFileContainingSymbol(
139 file_desc7 = self.pool.FindFileContainingSymbol(
[all …]

12345678910>>...79