You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apr.apache.org by ia...@apache.org on 2002/02/12 22:49:15 UTC

cvs commit: apr/include apr_atomic.h

ianh        02/02/12 13:49:15

  Added:       atomic/unix apr_atomic.c
               include  apr_atomic.h
  Log:
  atomic operation.
  still expermental
  
  Revision  Changes    Path
  1.1                  apr/atomic/unix/apr_atomic.c
  
  Index: apr_atomic.c
  ===================================================================
  #include "apr.h"
  #include "apr_lock.h"
  #include "apr_thread_mutex.h"
  #include "apr_atomic.h"
  
  #ifdef WIN32
  /* win32 implementation is all macros */
  #else
  
  #define NUM_ATOMIC_HASH 7
  /* shift by 2 to get rid of alignment issues */
  #define ATOMIC_HASH(x) (int)(((long)x>>2)%NUM_ATOMIC_HASH)
  static apr_thread_mutex_t **hash_mutex;
  
  apr_status_t apr_atomic_init(apr_pool_t *p )
  {
      int i;
      apr_status_t rv;
      hash_mutex =apr_palloc(p,sizeof(apr_thread_mutex_t*) * NUM_ATOMIC_HASH);
      for (i=0;i<NUM_ATOMIC_HASH;i++) {
          rv = apr_thread_mutex_create(&(hash_mutex[i]), APR_THREAD_MUTEX_DEFAULT, p);
          if (rv != APR_SUCCESS)
             return rv;
      }
      return APR_SUCCESS;
  }
  long apr_atomic_add(volatile long*mem, long val) 
  {
      apr_thread_mutex_t *lock = hash_mutex[ATOMIC_HASH(mem)];
      long prev;
         
      if (apr_thread_mutex_lock(lock) == APR_SUCCESS) {
          prev = *mem;
          *mem += val;
          apr_thread_mutex_unlock(lock);
          return prev;
      }
      return *mem;
  }
  long apr_atomic_set(volatile long*mem, long val) 
  {
      apr_thread_mutex_t *lock = hash_mutex[ATOMIC_HASH(mem)];
      long prev;
  
      if (apr_thread_mutex_lock(lock) == APR_SUCCESS) {
          prev = *mem;
          *mem = val;
          apr_thread_mutex_unlock(lock);
          return prev;
      }
      return *mem;
  }
  
  long apr_atomic_inc( volatile long *mem) 
  {
      apr_thread_mutex_t *lock = hash_mutex[ATOMIC_HASH(mem)];
      long prev;
  
      if (apr_thread_mutex_lock(lock) == APR_SUCCESS) {
          prev = *mem;
          (*mem)++;
          apr_thread_mutex_unlock(lock);
          return prev;
      }
      return *mem;
  }
  long apr_atomic_dec(volatile long *mem) 
  {
      apr_thread_mutex_t *lock = hash_mutex[ATOMIC_HASH(mem)];
      long prev;
  
      if (apr_thread_mutex_lock(lock) == APR_SUCCESS) {
          prev = *mem;
          (*mem)--;
          apr_thread_mutex_unlock(lock);
          return prev;
      }
      return *mem;
  }
  long apr_atomic_cas(volatile long *mem,long with,long cmp)
  {
      apr_thread_mutex_t *lock = hash_mutex[ATOMIC_HASH(mem)];
      long prev;
  
      if (apr_thread_mutex_lock(lock) == APR_SUCCESS) {
          prev = *mem;
          if ( *mem == cmp) {
              *mem = with;
          }
          apr_thread_mutex_unlock(lock);
          return prev;
      }
      return *mem;
  }
  #endif /* default implementation */
  
  
  
  1.1                  apr/include/apr_atomic.h
  
  Index: apr_atomic.h
  ===================================================================
  /* ====================================================================
   * The Apache Software License, Version 1.1
   *
   * Copyright (c) 2000-2001 The Apache Software Foundation.  All rights
   * reserved.
   *
   * Redistribution and use in source and binary forms, with or without
   * modification, are permitted provided that the following conditions
   * are met:
   *
   * 1. Redistributions of source code must retain the above copyright
   *    notice, this list of conditions and the following disclaimer.
   *
   * 2. Redistributions in binary form must reproduce the above copyright
   *    notice, this list of conditions and the following disclaimer in
   *    the documentation and/or other materials provided with the
   *    distribution.
   *
   * 3. The end-user documentation included with the redistribution,
   *    if any, must include the following acknowledgment:
   *       "This product includes software developed by the
   *        Apache Software Foundation (http://www.apache.org/)."
   *    Alternately, this acknowledgment may appear in the software itself,
   *    if and wherever such third-party acknowledgments normally appear.
   *
   * 4. The names "Apache" and "Apache Software Foundation" must
   *    not be used to endorse or promote products derived from this
   *    software without prior written permission. For written
   *    permission, please contact apache@apache.org.
   *
   * 5. Products derived from this software may not be called "Apache",
   *    nor may "Apache" appear in their name, without prior written
   *    permission of the Apache Software Foundation.
   *
   * THIS SOFTWARE IS PROVIDED ``AS IS'' AND ANY EXPRESSED OR IMPLIED
   * WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES
   * OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE
   * DISCLAIMED.  IN NO EVENT SHALL THE APACHE SOFTWARE FOUNDATION OR
   * ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL,
   * SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT
   * LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF
   * USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND
   * ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY,
   * OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT
   * OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
   * SUCH DAMAGE.
   * ====================================================================
   *
   * This software consists of voluntary contributions made by many
   * individuals on behalf of the Apache Software Foundation.  For more
   * information on the Apache Software Foundation, please see
   * <http://www.apache.org/>.
   *
   * Portions of this software are based upon public domain software
   * originally written at the National Center for Supercomputing Applications,
   * University of Illinois, Urbana-Champaign.
   */
  
  #ifndef APR_ATOMIC_H
  #define APR_ATOMIC_H
  
  #ifdef __cplusplus
  extern "C" {
  #endif
  #ifdef WIN32
  
  #define apr_atomic_add(mem, val)     InterlockedExchangeAdd(mem,val)
  #define apr_atomic_dec(mem)          InterlockedDecrement(mem)
  #define apr_atomic_inc(mem)          InterlockedIncrement(mem)
  #define apr_atomic_set(mem, val)     InterlockedExchange(mem, val)
  #define apr_atomic_read(mem)         *mem
  #define apr_atomic_cas(mem,with,cmp) InterlockedCompareExchange(mem,with,cmp)
  #define apr_atomic_init(pool)        APR_SUCCESS
  
  #else
  #define apr_atomic_read(p)  *p
  apr_status_t apr_atomic_init(apr_pool_t *p);
  long apr_atomic_set(volatile long*mem, long val);
  long apr_atomic_add(volatile long*mem, long val);
  long apr_atomic_inc( volatile long *mem);
  long apr_atomic_dec(volatile long *mem);
  long apr_atomic_cas(volatile long *mem,long with,long cmp);
  
  #endif
  #ifdef __cplusplus
  }
  #endif
  
  #endif	/* !APR_ATOMIC_H */
  
  
  

Re: cvs commit: apr/include apr_atomic.h

Posted by Jeff Trawick <tr...@attglobal.net>.
ianh@apache.org writes:

> ianh        02/02/12 13:49:15
> 
>   Added:       atomic/unix apr_atomic.c
>                include  apr_atomic.h


try building it with --disable-shared... I dare ya :)

-- 
Jeff Trawick | trawick@attglobal.net | PGP public key at web site:
       http://www.geocities.com/SiliconValley/Park/9289/
             Born in Roswell... married an alien...

Re: cvs commit: apr/include apr_atomic.h

Posted by Jeff Trawick <tr...@attglobal.net>.
ianh@apache.org writes:

> ianh        02/02/12 13:49:15
> 
>   Added:       atomic/unix apr_atomic.c
>                include  apr_atomic.h


try building it with --disable-shared... I dare ya :)

-- 
Jeff Trawick | trawick@attglobal.net | PGP public key at web site:
       http://www.geocities.com/SiliconValley/Park/9289/
             Born in Roswell... married an alien...