You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apr.apache.org by wr...@apache.org on 2007/10/23 23:16:22 UTC

svn commit: r587654 - in /apr/apr-util/branches/1.2.x/test: testqueue.c testreslist.c

Author: wrowe
Date: Tue Oct 23 14:16:21 2007
New Revision: 587654

URL: http://svn.apache.org/viewvc?rev=587654&view=rev
Log:
Fix these bogus lines; never toggle svn:eol-style while there
are windows droppings in svn

Modified:
    apr/apr-util/branches/1.2.x/test/testqueue.c   (contents, props changed)
    apr/apr-util/branches/1.2.x/test/testreslist.c   (contents, props changed)

Modified: apr/apr-util/branches/1.2.x/test/testqueue.c
URL: http://svn.apache.org/viewvc/apr/apr-util/branches/1.2.x/test/testqueue.c?rev=587654&r1=587653&r2=587654&view=diff
==============================================================================
--- apr/apr-util/branches/1.2.x/test/testqueue.c (original)
+++ apr/apr-util/branches/1.2.x/test/testqueue.c Tue Oct 23 14:16:21 2007
@@ -1,142 +1,142 @@
-/* Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-#include "apu.h"
-#include "apr_queue.h"
-#include "apr_thread_proc.h"
-#include "apr_time.h"
-#include "abts.h"
-#include "testutil.h"
-
-#if APR_HAS_THREADS
-
-#define NUMBER_CONSUMERS    3
-#define CONSUMER_ACTIVITY   4
-#define NUMBER_PRODUCERS    4
-#define PRODUCER_ACTIVITY   5
-#define QUEUE_SIZE          100
-#define SLEEP_TIME          30
-
-static apr_queue_t *queue;
-
-static void * APR_THREAD_FUNC consumer(apr_thread_t *thd, void *data)
-{
-    long sleeprate;
-    abts_case *tc = data;
-    apr_status_t rv;
-    void *v;
-
-    sleeprate = 1000000/CONSUMER_ACTIVITY;
-    apr_sleep( (rand() % 4 ) * 1000000 ); /* sleep random seconds */
-
-    while (1)
-    {
-        rv = apr_queue_pop(queue, &v);
-
-        if (rv == APR_EINTR)
-            continue;
-
-        if (rv == APR_EOF)
-            break;
-        
-        ABTS_TRUE(tc, v == NULL);
-        ABTS_TRUE(tc, rv == APR_SUCCESS);
-
-        apr_sleep( sleeprate ); /* sleep this long to acheive our rate */
-    }
-
-    apr_thread_exit(thd, rv);
-
-    /* not reached */
-    return NULL;
-} 
-
-static void * APR_THREAD_FUNC producer(apr_thread_t *thd, void *data)
-{
-    long sleeprate;
-    abts_case *tc = data;
-    apr_status_t rv;
-
-    sleeprate = 1000000/PRODUCER_ACTIVITY;
-    apr_sleep( (rand() % 4 ) * 1000000 ); /* sleep random seconds */
-
-    while (1)        
-    {
-        rv = apr_queue_push(queue, NULL);
-
-        if (rv == APR_EINTR)
-            continue;
-        
-        if (rv == APR_EOF)
-            break;
-
-        ABTS_TRUE(tc, rv == APR_SUCCESS);
-
-        apr_sleep( sleeprate ); /* sleep this long to acheive our rate */
-    }
-
-    apr_thread_exit(thd, rv);
-
-    /* not reached */
-    return NULL;
-} 
-
-static void test_queue_producer_consumer(abts_case *tc, void *data)
-{
-    unsigned int i;
-    apr_status_t rv;
-    apr_thread_t **t;
-
-    /* XXX: non-portable */
-    srand((unsigned int)apr_time_now());
-    
-    rv = apr_queue_create(&queue, QUEUE_SIZE, p);
-    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-
-    t = apr_palloc(p, sizeof(apr_thread_t*) * (NUMBER_CONSUMERS 
-                                             + NUMBER_PRODUCERS));
-    for (i = 0; i < NUMBER_CONSUMERS; ++i) {
-        rv = apr_thread_create(&t[i], NULL, consumer, tc, p);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-    for (i = NUMBER_CONSUMERS; i < NUMBER_CONSUMERS + NUMBER_PRODUCERS; ++i) {
-        rv = apr_thread_create(&t[i], NULL, producer, tc, p);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    apr_sleep(SLEEP_TIME * 1000000); /* sleep 10 seconds */
-
-    rv = apr_queue_term(queue);
-    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-
-    for (i = 0; i < NUMBER_CONSUMERS + NUMBER_PRODUCERS; ++i) {
-        apr_thread_join(&rv, t[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_EOF);
-    }
-}
-
-#endif /* APR_HAS_THREADS */
-
-abts_suite *testqueue(abts_suite *suite)
-{
-    suite = ADD_SUITE(suite);
-
-#if APR_HAS_THREADS
-    abts_run_test(suite, test_queue_producer_consumer, NULL);
-#endif /* APR_HAS_THREADS */
-
-    return suite;
-}
+/* Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include "apu.h"
+#include "apr_queue.h"
+#include "apr_thread_proc.h"
+#include "apr_time.h"
+#include "abts.h"
+#include "testutil.h"
+
+#if APR_HAS_THREADS
+
+#define NUMBER_CONSUMERS    3
+#define CONSUMER_ACTIVITY   4
+#define NUMBER_PRODUCERS    4
+#define PRODUCER_ACTIVITY   5
+#define QUEUE_SIZE          100
+#define SLEEP_TIME          30
+
+static apr_queue_t *queue;
+
+static void * APR_THREAD_FUNC consumer(apr_thread_t *thd, void *data)
+{
+    long sleeprate;
+    abts_case *tc = data;
+    apr_status_t rv;
+    void *v;
+
+    sleeprate = 1000000/CONSUMER_ACTIVITY;
+    apr_sleep( (rand() % 4 ) * 1000000 ); /* sleep random seconds */
+
+    while (1)
+    {
+        rv = apr_queue_pop(queue, &v);
+
+        if (rv == APR_EINTR)
+            continue;
+
+        if (rv == APR_EOF)
+            break;
+        
+        ABTS_TRUE(tc, v == NULL);
+        ABTS_TRUE(tc, rv == APR_SUCCESS);
+
+        apr_sleep( sleeprate ); /* sleep this long to acheive our rate */
+    }
+
+    apr_thread_exit(thd, rv);
+
+    /* not reached */
+    return NULL;
+} 
+
+static void * APR_THREAD_FUNC producer(apr_thread_t *thd, void *data)
+{
+    long sleeprate;
+    abts_case *tc = data;
+    apr_status_t rv;
+
+    sleeprate = 1000000/PRODUCER_ACTIVITY;
+    apr_sleep( (rand() % 4 ) * 1000000 ); /* sleep random seconds */
+
+    while (1)        
+    {
+        rv = apr_queue_push(queue, NULL);
+
+        if (rv == APR_EINTR)
+            continue;
+        
+        if (rv == APR_EOF)
+            break;
+
+        ABTS_TRUE(tc, rv == APR_SUCCESS);
+
+        apr_sleep( sleeprate ); /* sleep this long to acheive our rate */
+    }
+
+    apr_thread_exit(thd, rv);
+
+    /* not reached */
+    return NULL;
+} 
+
+static void test_queue_producer_consumer(abts_case *tc, void *data)
+{
+    unsigned int i;
+    apr_status_t rv;
+    apr_thread_t **t;
+
+    /* XXX: non-portable */
+    srand((unsigned int)apr_time_now());
+    
+    rv = apr_queue_create(&queue, QUEUE_SIZE, p);
+    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+
+    t = apr_palloc(p, sizeof(apr_thread_t*) * (NUMBER_CONSUMERS 
+                                             + NUMBER_PRODUCERS));
+    for (i = 0; i < NUMBER_CONSUMERS; ++i) {
+        rv = apr_thread_create(&t[i], NULL, consumer, tc, p);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+    for (i = NUMBER_CONSUMERS; i < NUMBER_CONSUMERS + NUMBER_PRODUCERS; ++i) {
+        rv = apr_thread_create(&t[i], NULL, producer, tc, p);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    apr_sleep(SLEEP_TIME * 1000000); /* sleep 10 seconds */
+
+    rv = apr_queue_term(queue);
+    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+
+    for (i = 0; i < NUMBER_CONSUMERS + NUMBER_PRODUCERS; ++i) {
+        apr_thread_join(&rv, t[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_EOF);
+    }
+}
+
+#endif /* APR_HAS_THREADS */
+
+abts_suite *testqueue(abts_suite *suite)
+{
+    suite = ADD_SUITE(suite);
+
+#if APR_HAS_THREADS
+    abts_run_test(suite, test_queue_producer_consumer, NULL);
+#endif /* APR_HAS_THREADS */
+
+    return suite;
+}

Propchange: apr/apr-util/branches/1.2.x/test/testqueue.c
            ('svn:eol-style' removed)

Modified: apr/apr-util/branches/1.2.x/test/testreslist.c
URL: http://svn.apache.org/viewvc/apr/apr-util/branches/1.2.x/test/testreslist.c?rev=587654&r1=587653&r2=587654&view=diff
==============================================================================
--- apr/apr-util/branches/1.2.x/test/testreslist.c (original)
+++ apr/apr-util/branches/1.2.x/test/testreslist.c Tue Oct 23 14:16:21 2007
@@ -1,277 +1,277 @@
-/* Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-#include <stdio.h>
-#include <stdlib.h>
-#include "apr_general.h"
-#include "apu.h"
-#include "apr_reslist.h"
-#include "apr_thread_proc.h"
-#if APR_HAVE_TIME_H
-#include <time.h>
-#endif /* APR_HAVE_TIME_H */
-
-#include "abts.h"
-#include "testutil.h"
-
-#if APR_HAS_THREADS
-
-#define RESLIST_MIN   3
-#define RESLIST_SMAX 10
-#define RESLIST_HMAX 20
-#define RESLIST_TTL  APR_TIME_C(350000) /* 35 ms */
-#define CONSUMER_THREADS 25
-#define CONSUMER_ITERATIONS 250
-#define CONSTRUCT_SLEEP_TIME  APR_TIME_C(250000) /* 25 ms */
-#define DESTRUCT_SLEEP_TIME   APR_TIME_C(100000) /* 10 ms */
-#define WORK_DELAY_SLEEP_TIME APR_TIME_C(150000) /* 15 ms */
-
-typedef struct {
-    apr_interval_time_t sleep_upon_construct;
-    apr_interval_time_t sleep_upon_destruct;
-    int c_count;
-    int d_count;
-} my_parameters_t;
-
-typedef struct {
-    int id;
-} my_resource_t;
-
-/* Linear congruential generator */
-static apr_uint32_t lgc(apr_uint32_t a)
-{
-    apr_uint64_t z = a;
-    z *= 279470273;
-    z %= APR_UINT64_C(4294967291);
-    return (apr_uint32_t)z;
-}
-
-static apr_status_t my_constructor(void **resource, void *params,
-                                   apr_pool_t *pool)
-{
-    my_resource_t *res;
-    my_parameters_t *my_params = params;
-
-    /* Create some resource */
-    res = apr_palloc(pool, sizeof(*res));
-    res->id = my_params->c_count++;
-
-    /* Sleep for awhile, to simulate construction overhead. */
-    apr_sleep(my_params->sleep_upon_construct);
-
-    /* Set the resource so it can be managed by the reslist */
-    *resource = res;
-    return APR_SUCCESS;
-}
-
-static apr_status_t my_destructor(void *resource, void *params,
-                                  apr_pool_t *pool)
-{
-    my_resource_t *res = resource;
-    my_parameters_t *my_params = params;
-    res->id = my_params->d_count++;
-
-    apr_sleep(my_params->sleep_upon_destruct);
-
-    return APR_SUCCESS;
-}
-
-typedef struct {
-    int tid;
-    abts_case *tc;
-    apr_reslist_t *reslist;
-    apr_interval_time_t work_delay_sleep;
-} my_thread_info_t;
-
-#define PERCENT95th ( ( 2u^31 / 10u ) * 19u )
-
-static void * APR_THREAD_FUNC resource_consuming_thread(apr_thread_t *thd,
-                                                        void *data)
-{
-    int i;
-    apr_uint32_t chance;
-    void *vp;
-    apr_status_t rv;
-    my_resource_t *res;
-    my_thread_info_t *thread_info = data;
-    apr_reslist_t *rl = thread_info->reslist;
-
-    apr_generate_random_bytes((void*)&chance, sizeof(chance));
-
-    for (i = 0; i < CONSUMER_ITERATIONS; i++) {
-        rv = apr_reslist_acquire(rl, &vp);
-        ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
-        res = vp;
-        apr_sleep(thread_info->work_delay_sleep);
-
-        /* simulate a 5% chance of the resource being bad */
-        chance = lgc(chance);
-        if ( chance < PERCENT95th ) {
-            rv = apr_reslist_release(rl, res);
-            ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
-       } else {
-            rv = apr_reslist_invalidate(rl, res);
-            ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
-       }
-    }
-
-    return APR_SUCCESS;
-}
-
-static void test_timeout(abts_case *tc, apr_reslist_t *rl)
-{
-    apr_status_t rv;
-    my_resource_t *resources[RESLIST_HMAX];
-    my_resource_t *res;
-    void *vp;
-    int i;
-
-    apr_reslist_timeout_set(rl, 1000);
-
-    /* deplete all possible resources from the resource list 
-     * so that the next call will block until timeout is reached 
-     * (since there are no other threads to make a resource 
-     * available)
-     */
-
-    for (i = 0; i < RESLIST_HMAX; i++) {
-        rv = apr_reslist_acquire(rl, (void**)&resources[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    /* next call will block until timeout is reached */
-    rv = apr_reslist_acquire(rl, &vp);
-    ABTS_TRUE(tc, APR_STATUS_IS_TIMEUP(rv));
-
-    res = vp;
-
-    /* release the resources; otherwise the destroy operation
-     * will blow
-     */
-    for (i = 0; i < RESLIST_HMAX; i++) {
-        rv = apr_reslist_release(rl, resources[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-}
-
-static void test_shrinking(abts_case *tc, apr_reslist_t *rl)
-{
-    apr_status_t rv;
-    my_resource_t *resources[RESLIST_HMAX];
-    my_resource_t *res;
-    void *vp;
-    int i;
-    int sleep_time = RESLIST_TTL / RESLIST_HMAX;
-
-    /* deplete all possible resources from the resource list */
-    for (i = 0; i < RESLIST_HMAX; i++) {
-        rv = apr_reslist_acquire(rl, (void**)&resources[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    /* Free all resources above RESLIST_SMAX - 1 */
-    for (i = RESLIST_SMAX - 1; i < RESLIST_HMAX; i++) {
-        rv = apr_reslist_release(rl, resources[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    for (i = 0; i < RESLIST_HMAX; i++) {
-        rv = apr_reslist_acquire(rl, &vp);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-        res = vp;
-        apr_sleep(sleep_time);
-        rv = apr_reslist_release(rl, res);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-    apr_sleep(sleep_time);
-
-    /*
-     * Now free the remaining elements. This should trigger the shrinking of
-     * the list
-     */
-    for (i = 0; i < RESLIST_SMAX - 1; i++) {
-        rv = apr_reslist_release(rl, resources[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-}
-
-static void test_reslist(abts_case *tc, void *data)
-{
-    int i;
-    apr_pool_t *p;
-    apr_status_t rv;
-    apr_reslist_t *rl;
-    my_parameters_t *params;
-    apr_thread_t *my_threads[CONSUMER_THREADS];
-    my_thread_info_t my_thread_info[CONSUMER_THREADS];
-
-    rv = apr_pool_create(&p, NULL);
-    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-
-    /* Create some parameters that will be passed into each
-     * constructor and destructor call. */
-    params = apr_pcalloc(p, sizeof(*params));
-    params->sleep_upon_construct = CONSTRUCT_SLEEP_TIME;
-    params->sleep_upon_destruct = DESTRUCT_SLEEP_TIME;
-
-    /* We're going to want 10 blocks of data from our target rmm. */
-    rv = apr_reslist_create(&rl, RESLIST_MIN, RESLIST_SMAX, RESLIST_HMAX,
-                            RESLIST_TTL, my_constructor, my_destructor,
-                            params, p);
-    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-
-    for (i = 0; i < CONSUMER_THREADS; i++) {
-        putchar('.');
-        my_thread_info[i].tid = i;
-        my_thread_info[i].tc = tc;
-        my_thread_info[i].reslist = rl;
-        my_thread_info[i].work_delay_sleep = WORK_DELAY_SLEEP_TIME;
-        rv = apr_thread_create(&my_threads[i], NULL,
-                               resource_consuming_thread, &my_thread_info[i],
-                               p);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    for (i = 0; i < CONSUMER_THREADS; i++) {
-        apr_status_t thread_rv;
-        apr_thread_join(&thread_rv, my_threads[i]);
-        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-    }
-
-    test_timeout(tc, rl);
-
-    test_shrinking(tc, rl);
-    ABTS_INT_EQUAL(tc, RESLIST_SMAX, params->c_count - params->d_count);
-
-    rv = apr_reslist_destroy(rl);
-    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
-
-    apr_pool_destroy(p);
-}
-
-
-#endif /* APR_HAS_THREADS */
-
-abts_suite *testreslist(abts_suite *suite)
-{
-    suite = ADD_SUITE(suite);
-
-#if APR_HAS_THREADS
-    abts_run_test(suite, test_reslist, NULL);
-#endif
-
-    return suite;
-}
+/* Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+#include <stdio.h>
+#include <stdlib.h>
+#include "apr_general.h"
+#include "apu.h"
+#include "apr_reslist.h"
+#include "apr_thread_proc.h"
+#if APR_HAVE_TIME_H
+#include <time.h>
+#endif /* APR_HAVE_TIME_H */
+
+#include "abts.h"
+#include "testutil.h"
+
+#if APR_HAS_THREADS
+
+#define RESLIST_MIN   3
+#define RESLIST_SMAX 10
+#define RESLIST_HMAX 20
+#define RESLIST_TTL  APR_TIME_C(350000) /* 35 ms */
+#define CONSUMER_THREADS 25
+#define CONSUMER_ITERATIONS 250
+#define CONSTRUCT_SLEEP_TIME  APR_TIME_C(250000) /* 25 ms */
+#define DESTRUCT_SLEEP_TIME   APR_TIME_C(100000) /* 10 ms */
+#define WORK_DELAY_SLEEP_TIME APR_TIME_C(150000) /* 15 ms */
+
+typedef struct {
+    apr_interval_time_t sleep_upon_construct;
+    apr_interval_time_t sleep_upon_destruct;
+    int c_count;
+    int d_count;
+} my_parameters_t;
+
+typedef struct {
+    int id;
+} my_resource_t;
+
+/* Linear congruential generator */
+static apr_uint32_t lgc(apr_uint32_t a)
+{
+    apr_uint64_t z = a;
+    z *= 279470273;
+    z %= APR_UINT64_C(4294967291);
+    return (apr_uint32_t)z;
+}
+
+static apr_status_t my_constructor(void **resource, void *params,
+                                   apr_pool_t *pool)
+{
+    my_resource_t *res;
+    my_parameters_t *my_params = params;
+
+    /* Create some resource */
+    res = apr_palloc(pool, sizeof(*res));
+    res->id = my_params->c_count++;
+
+    /* Sleep for awhile, to simulate construction overhead. */
+    apr_sleep(my_params->sleep_upon_construct);
+
+    /* Set the resource so it can be managed by the reslist */
+    *resource = res;
+    return APR_SUCCESS;
+}
+
+static apr_status_t my_destructor(void *resource, void *params,
+                                  apr_pool_t *pool)
+{
+    my_resource_t *res = resource;
+    my_parameters_t *my_params = params;
+    res->id = my_params->d_count++;
+
+    apr_sleep(my_params->sleep_upon_destruct);
+
+    return APR_SUCCESS;
+}
+
+typedef struct {
+    int tid;
+    abts_case *tc;
+    apr_reslist_t *reslist;
+    apr_interval_time_t work_delay_sleep;
+} my_thread_info_t;
+
+#define PERCENT95th ( ( 2u^31 / 10u ) * 19u )
+
+static void * APR_THREAD_FUNC resource_consuming_thread(apr_thread_t *thd,
+                                                        void *data)
+{
+    int i;
+    apr_uint32_t chance;
+    void *vp;
+    apr_status_t rv;
+    my_resource_t *res;
+    my_thread_info_t *thread_info = data;
+    apr_reslist_t *rl = thread_info->reslist;
+
+    apr_generate_random_bytes((void*)&chance, sizeof(chance));
+
+    for (i = 0; i < CONSUMER_ITERATIONS; i++) {
+        rv = apr_reslist_acquire(rl, &vp);
+        ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
+        res = vp;
+        apr_sleep(thread_info->work_delay_sleep);
+
+        /* simulate a 5% chance of the resource being bad */
+        chance = lgc(chance);
+        if ( chance < PERCENT95th ) {
+            rv = apr_reslist_release(rl, res);
+            ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
+       } else {
+            rv = apr_reslist_invalidate(rl, res);
+            ABTS_INT_EQUAL(thread_info->tc, rv, APR_SUCCESS);
+       }
+    }
+
+    return APR_SUCCESS;
+}
+
+static void test_timeout(abts_case *tc, apr_reslist_t *rl)
+{
+    apr_status_t rv;
+    my_resource_t *resources[RESLIST_HMAX];
+    my_resource_t *res;
+    void *vp;
+    int i;
+
+    apr_reslist_timeout_set(rl, 1000);
+
+    /* deplete all possible resources from the resource list 
+     * so that the next call will block until timeout is reached 
+     * (since there are no other threads to make a resource 
+     * available)
+     */
+
+    for (i = 0; i < RESLIST_HMAX; i++) {
+        rv = apr_reslist_acquire(rl, (void**)&resources[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    /* next call will block until timeout is reached */
+    rv = apr_reslist_acquire(rl, &vp);
+    ABTS_TRUE(tc, APR_STATUS_IS_TIMEUP(rv));
+
+    res = vp;
+
+    /* release the resources; otherwise the destroy operation
+     * will blow
+     */
+    for (i = 0; i < RESLIST_HMAX; i++) {
+        rv = apr_reslist_release(rl, resources[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+}
+
+static void test_shrinking(abts_case *tc, apr_reslist_t *rl)
+{
+    apr_status_t rv;
+    my_resource_t *resources[RESLIST_HMAX];
+    my_resource_t *res;
+    void *vp;
+    int i;
+    int sleep_time = RESLIST_TTL / RESLIST_HMAX;
+
+    /* deplete all possible resources from the resource list */
+    for (i = 0; i < RESLIST_HMAX; i++) {
+        rv = apr_reslist_acquire(rl, (void**)&resources[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    /* Free all resources above RESLIST_SMAX - 1 */
+    for (i = RESLIST_SMAX - 1; i < RESLIST_HMAX; i++) {
+        rv = apr_reslist_release(rl, resources[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    for (i = 0; i < RESLIST_HMAX; i++) {
+        rv = apr_reslist_acquire(rl, &vp);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+        res = vp;
+        apr_sleep(sleep_time);
+        rv = apr_reslist_release(rl, res);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+    apr_sleep(sleep_time);
+
+    /*
+     * Now free the remaining elements. This should trigger the shrinking of
+     * the list
+     */
+    for (i = 0; i < RESLIST_SMAX - 1; i++) {
+        rv = apr_reslist_release(rl, resources[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+}
+
+static void test_reslist(abts_case *tc, void *data)
+{
+    int i;
+    apr_pool_t *p;
+    apr_status_t rv;
+    apr_reslist_t *rl;
+    my_parameters_t *params;
+    apr_thread_t *my_threads[CONSUMER_THREADS];
+    my_thread_info_t my_thread_info[CONSUMER_THREADS];
+
+    rv = apr_pool_create(&p, NULL);
+    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+
+    /* Create some parameters that will be passed into each
+     * constructor and destructor call. */
+    params = apr_pcalloc(p, sizeof(*params));
+    params->sleep_upon_construct = CONSTRUCT_SLEEP_TIME;
+    params->sleep_upon_destruct = DESTRUCT_SLEEP_TIME;
+
+    /* We're going to want 10 blocks of data from our target rmm. */
+    rv = apr_reslist_create(&rl, RESLIST_MIN, RESLIST_SMAX, RESLIST_HMAX,
+                            RESLIST_TTL, my_constructor, my_destructor,
+                            params, p);
+    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+
+    for (i = 0; i < CONSUMER_THREADS; i++) {
+        putchar('.');
+        my_thread_info[i].tid = i;
+        my_thread_info[i].tc = tc;
+        my_thread_info[i].reslist = rl;
+        my_thread_info[i].work_delay_sleep = WORK_DELAY_SLEEP_TIME;
+        rv = apr_thread_create(&my_threads[i], NULL,
+                               resource_consuming_thread, &my_thread_info[i],
+                               p);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    for (i = 0; i < CONSUMER_THREADS; i++) {
+        apr_status_t thread_rv;
+        apr_thread_join(&thread_rv, my_threads[i]);
+        ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+    }
+
+    test_timeout(tc, rl);
+
+    test_shrinking(tc, rl);
+    ABTS_INT_EQUAL(tc, RESLIST_SMAX, params->c_count - params->d_count);
+
+    rv = apr_reslist_destroy(rl);
+    ABTS_INT_EQUAL(tc, rv, APR_SUCCESS);
+
+    apr_pool_destroy(p);
+}
+
+
+#endif /* APR_HAS_THREADS */
+
+abts_suite *testreslist(abts_suite *suite)
+{
+    suite = ADD_SUITE(suite);
+
+#if APR_HAS_THREADS
+    abts_run_test(suite, test_reslist, NULL);
+#endif
+
+    return suite;
+}

Propchange: apr/apr-util/branches/1.2.x/test/testreslist.c
            ('svn:eol-style' removed)